DELETE Bulk delete activities
{{baseUrl}}/activities/bulkDelete
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/activities/bulkDelete");

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  \"id\": []\n}");

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

(client/delete "{{baseUrl}}/activities/bulkDelete" {:content-type :json
                                                                    :form-params {:id []}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/activities/bulkDelete"

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

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

}
DELETE /baseUrl/activities/bulkDelete HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/activities/bulkDelete")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/activities/bulkDelete")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

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

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

xhr.open('DELETE', '{{baseUrl}}/activities/bulkDelete');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/activities/bulkDelete',
  headers: {'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/activities/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/activities/bulkDelete',
  method: 'DELETE',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/activities/bulkDelete")
  .delete(body)
  .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/activities/bulkDelete',
  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({id: []}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/activities/bulkDelete',
  headers: {'content-type': 'application/json'},
  body: {id: []},
  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}}/activities/bulkDelete');

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

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

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}}/activities/bulkDelete',
  headers: {'content-type': 'application/json'},
  data: {id: []}
};

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

const url = '{{baseUrl}}/activities/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'content-type': 'application/json'},
  body: '{"id":[]}'
};

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 = @{ @"id": @[  ] };

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

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

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

echo $response->getBody();
setUrl('{{baseUrl}}/activities/bulkDelete');
$request->setMethod(HTTP_METH_DELETE);

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

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

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

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

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

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

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

conn.request("DELETE", "/baseUrl/activities/bulkDelete", payload, headers)

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

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

url = "{{baseUrl}}/activities/bulkDelete"

payload = { "id": [] }
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/activities/bulkDelete"

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

encode <- "json"

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

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

url = URI("{{baseUrl}}/activities/bulkDelete")

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

request = Net::HTTP::Delete.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/activities/bulkDelete') do |req|
  req.body = "{\n  \"id\": []\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}}/activities/bulkDelete";

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

    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("DELETE").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

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

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/activities/bulkDelete \
  --header 'content-type: application/json' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http DELETE {{baseUrl}}/activities/bulkDelete \
  content-type:application/json
wget --quiet \
  --method DELETE \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/activities/bulkDelete
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["id": []] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/activities/bulkDelete")! 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 Create an activity
{{baseUrl}}/activities
BODY json

{
  "hex_code": "",
  "name": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"hex_code\": \"\",\n  \"name\": \"\"\n}");

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

(client/post "{{baseUrl}}/activities" {:content-type :json
                                                       :form-params {:hex_code ""
                                                                     :name ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/activities"

	payload := strings.NewReader("{\n  \"hex_code\": \"\",\n  \"name\": \"\"\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/activities HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 34

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/activities',
  headers: {'content-type': 'application/json'},
  data: {hex_code: '', name: ''}
};

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

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

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

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

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

const url = '{{baseUrl}}/activities';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"hex_code":"","name":""}'
};

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 = @{ @"hex_code": @"",
                              @"name": @"" };

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

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

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

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

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

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

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

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

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

payload = "{\n  \"hex_code\": \"\",\n  \"name\": \"\"\n}"

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

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

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

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

url = "{{baseUrl}}/activities"

payload = {
    "hex_code": "",
    "name": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/activities"

payload <- "{\n  \"hex_code\": \"\",\n  \"name\": \"\"\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}}/activities")

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

    let payload = json!({
        "hex_code": "",
        "name": ""
    });

    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}}/activities \
  --header 'content-type: application/json' \
  --data '{
  "hex_code": "",
  "name": ""
}'
echo '{
  "hex_code": "",
  "name": ""
}' |  \
  http POST {{baseUrl}}/activities \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "hex_code": "",\n  "name": ""\n}' \
  --output-document \
  - {{baseUrl}}/activities
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "hex_code": "",
  "name": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/activities")! 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 Delete an activity
{{baseUrl}}/activities/:activity_id
QUERY PARAMS

activity_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/activities/:activity_id");

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

(client/delete "{{baseUrl}}/activities/:activity_id")
require "http/client"

url = "{{baseUrl}}/activities/:activity_id"

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

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

func main() {

	url := "{{baseUrl}}/activities/:activity_id"

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

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

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

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

}
DELETE /baseUrl/activities/:activity_id HTTP/1.1
Host: example.com

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/activities/:activity_id"))
    .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}}/activities/:activity_id")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/activities/:activity_id")
  .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}}/activities/:activity_id');

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

const options = {method: 'DELETE', url: '{{baseUrl}}/activities/:activity_id'};

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

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/activities/:activity_id")
  .delete(null)
  .build()

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

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

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

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

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

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

const options = {method: 'DELETE', url: '{{baseUrl}}/activities/:activity_id'};

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

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

const req = unirest('DELETE', '{{baseUrl}}/activities/:activity_id');

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}}/activities/:activity_id'};

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

const url = '{{baseUrl}}/activities/:activity_id';
const options = {method: 'DELETE'};

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

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

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

let uri = Uri.of_string "{{baseUrl}}/activities/:activity_id" in

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

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

curl_close($curl);

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

echo $response->getBody();
setUrl('{{baseUrl}}/activities/:activity_id');
$request->setMethod(HTTP_METH_DELETE);

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

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

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

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

conn.request("DELETE", "/baseUrl/activities/:activity_id")

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

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

url = "{{baseUrl}}/activities/:activity_id"

response = requests.delete(url)

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

url <- "{{baseUrl}}/activities/:activity_id"

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

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

url = URI("{{baseUrl}}/activities/:activity_id")

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

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

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

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

response = conn.delete('/baseUrl/activities/:activity_id') do |req|
end

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

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

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

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

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

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

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

dataTask.resume()
PUT Edit an activity
{{baseUrl}}/activities/:activity_id
QUERY PARAMS

activity_id
BODY json

{
  "hex_code": "",
  "name": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/activities/:activity_id");

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  \"hex_code\": \"\",\n  \"name\": \"\"\n}");

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

(client/put "{{baseUrl}}/activities/:activity_id" {:content-type :json
                                                                   :form-params {:hex_code ""
                                                                                 :name ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/activities/:activity_id"

	payload := strings.NewReader("{\n  \"hex_code\": \"\",\n  \"name\": \"\"\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/activities/:activity_id HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 34

{
  "hex_code": "",
  "name": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/activities/:activity_id")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"hex_code\": \"\",\n  \"name\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/activities/:activity_id',
  headers: {'content-type': 'application/json'},
  data: {hex_code: '', name: ''}
};

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

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

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

req.type('json');
req.send({
  hex_code: '',
  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}}/activities/:activity_id',
  headers: {'content-type': 'application/json'},
  data: {hex_code: '', name: ''}
};

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

const url = '{{baseUrl}}/activities/:activity_id';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"hex_code":"","name":""}'
};

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 = @{ @"hex_code": @"",
                              @"name": @"" };

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

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

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

echo $response->getBody();
setUrl('{{baseUrl}}/activities/:activity_id');
$request->setMethod(HTTP_METH_PUT);

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

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

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

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

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

payload = "{\n  \"hex_code\": \"\",\n  \"name\": \"\"\n}"

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

conn.request("PUT", "/baseUrl/activities/:activity_id", payload, headers)

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

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

url = "{{baseUrl}}/activities/:activity_id"

payload = {
    "hex_code": "",
    "name": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/activities/:activity_id"

payload <- "{\n  \"hex_code\": \"\",\n  \"name\": \"\"\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}}/activities/:activity_id")

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

    let payload = json!({
        "hex_code": "",
        "name": ""
    });

    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}}/activities/:activity_id \
  --header 'content-type: application/json' \
  --data '{
  "hex_code": "",
  "name": ""
}'
echo '{
  "hex_code": "",
  "name": ""
}' |  \
  http PUT {{baseUrl}}/activities/:activity_id \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "hex_code": "",\n  "name": ""\n}' \
  --output-document \
  - {{baseUrl}}/activities/:activity_id
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "hex_code": "",
  "name": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/activities/:activity_id")! 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 Get a list of activities
{{baseUrl}}/activities
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

(client/get "{{baseUrl}}/activities")
require "http/client"

url = "{{baseUrl}}/activities"

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}}/activities"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/activities");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/activities"

	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/activities HTTP/1.1
Host: example.com

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/activities"))
    .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}}/activities")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/activities")
  .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}}/activities');

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

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

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/activities';
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}}/activities',
  method: 'GET',
  headers: {}
};

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

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

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/activities',
  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}}/activities'};

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

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

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

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}}/activities'};

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

const url = '{{baseUrl}}/activities';
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}}/activities"]
                                                       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}}/activities" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/activities",
  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}}/activities');

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

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

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

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

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

conn.request("GET", "/baseUrl/activities")

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

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

url = "{{baseUrl}}/activities"

response = requests.get(url)

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

url <- "{{baseUrl}}/activities"

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

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

url = URI("{{baseUrl}}/activities")

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/activities') do |req|
end

puts response.status
puts response.body
use reqwest;

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

    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}}/activities
http GET {{baseUrl}}/activities
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/activities
import Foundation

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

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

dataTask.resume()
GET Get list of changelog history for the offer. Returns offer object with contact and user objects if they are provided
{{baseUrl}}/offers/:offer_id/changelog
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/offers/:offer_id/changelog");

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

(client/get "{{baseUrl}}/offers/:offer_id/changelog")
require "http/client"

url = "{{baseUrl}}/offers/:offer_id/changelog"

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}}/offers/:offer_id/changelog"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/offers/:offer_id/changelog");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/offers/:offer_id/changelog"

	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/offers/:offer_id/changelog HTTP/1.1
Host: example.com

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/offers/:offer_id/changelog"))
    .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}}/offers/:offer_id/changelog")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/offers/:offer_id/changelog")
  .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}}/offers/:offer_id/changelog');

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

const options = {method: 'GET', url: '{{baseUrl}}/offers/:offer_id/changelog'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/offers/:offer_id/changelog';
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}}/offers/:offer_id/changelog',
  method: 'GET',
  headers: {}
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/offers/:offer_id/changelog")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/offers/:offer_id/changelog',
  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}}/offers/:offer_id/changelog'};

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

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

const req = unirest('GET', '{{baseUrl}}/offers/:offer_id/changelog');

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}}/offers/:offer_id/changelog'};

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

const url = '{{baseUrl}}/offers/:offer_id/changelog';
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}}/offers/:offer_id/changelog"]
                                                       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}}/offers/:offer_id/changelog" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/offers/:offer_id/changelog",
  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}}/offers/:offer_id/changelog');

echo $response->getBody();
setUrl('{{baseUrl}}/offers/:offer_id/changelog');
$request->setMethod(HTTP_METH_GET);

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

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

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

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

conn.request("GET", "/baseUrl/offers/:offer_id/changelog")

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

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

url = "{{baseUrl}}/offers/:offer_id/changelog"

response = requests.get(url)

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

url <- "{{baseUrl}}/offers/:offer_id/changelog"

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

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

url = URI("{{baseUrl}}/offers/:offer_id/changelog")

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/offers/:offer_id/changelog') do |req|
end

puts response.status
puts response.body
use reqwest;

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

    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}}/offers/:offer_id/changelog
http GET {{baseUrl}}/offers/:offer_id/changelog
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/offers/:offer_id/changelog
import Foundation

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

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

dataTask.resume()
GET Get details about one city
{{baseUrl}}/cities/:city_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

city_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/cities/:city_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/cities/:city_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/cities/:city_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/cities/:city_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/cities/:city_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/cities/:city_id"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
GET /baseUrl/cities/:city_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/cities/:city_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/cities/:city_id"))
    .header("x-auth-token", "{{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}}/cities/:city_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/cities/:city_id")
  .header("x-auth-token", "{{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}}/cities/:city_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/cities/:city_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/cities/:city_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/cities/:city_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/cities/:city_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/cities/:city_id',
  headers: {
    'x-auth-token': '{{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}}/cities/:city_id',
  headers: {'x-auth-token': '{{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}}/cities/:city_id');

req.headers({
  'x-auth-token': '{{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}}/cities/:city_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/cities/:city_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/cities/:city_id"]
                                                       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}}/cities/:city_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/cities/:city_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/cities/:city_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/cities/:city_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/cities/:city_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/cities/:city_id' -Method GET -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/cities/:city_id", headers=headers)

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

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

url = "{{baseUrl}}/cities/:city_id"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/cities/:city_id"

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

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

url = URI("{{baseUrl}}/cities/:city_id")

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

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/cities/:city_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/cities/:city_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/cities/:city_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/cities/:city_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/cities/:city_id")! 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 list of cities supported in Apacta
{{baseUrl}}/cities
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/cities" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/cities"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/cities"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/cities");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/cities"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
GET /baseUrl/cities HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/cities',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/cities';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/cities',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/cities")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/cities',
  headers: {
    'x-auth-token': '{{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}}/cities',
  headers: {'x-auth-token': '{{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}}/cities');

req.headers({
  'x-auth-token': '{{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}}/cities',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/cities';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/cities"]
                                                       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}}/cities" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/cities', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

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

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/cities');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

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

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/cities", headers=headers)

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

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

url = "{{baseUrl}}/cities"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/cities"

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

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

url = URI("{{baseUrl}}/cities")

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

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/cities') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/cities \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/cities \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/cities
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/cities")! 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 Checkout active clocking record for authenticated user
{{baseUrl}}/clocking_records/checkout
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/clocking_records/checkout");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/post "{{baseUrl}}/clocking_records/checkout" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/clocking_records/checkout"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
}

response = HTTP::Client.post url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/clocking_records/checkout"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/clocking_records/checkout");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/clocking_records/checkout"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
POST /baseUrl/clocking_records/checkout HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/clocking_records/checkout")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/clocking_records/checkout"))
    .header("x-auth-token", "{{apiKey}}")
    .method("POST", 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}}/clocking_records/checkout")
  .post(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/clocking_records/checkout")
  .header("x-auth-token", "{{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('POST', '{{baseUrl}}/clocking_records/checkout');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/clocking_records/checkout',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/clocking_records/checkout';
const options = {method: 'POST', headers: {'x-auth-token': '{{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}}/clocking_records/checkout',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/clocking_records/checkout")
  .post(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/clocking_records/checkout',
  headers: {
    'x-auth-token': '{{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: 'POST',
  url: '{{baseUrl}}/clocking_records/checkout',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

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

const req = unirest('POST', '{{baseUrl}}/clocking_records/checkout');

req.headers({
  'x-auth-token': '{{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: 'POST',
  url: '{{baseUrl}}/clocking_records/checkout',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/clocking_records/checkout';
const options = {method: 'POST', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/clocking_records/checkout"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[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}}/clocking_records/checkout" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/clocking_records/checkout",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/clocking_records/checkout', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

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

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/clocking_records/checkout');
$request->setRequestMethod('POST');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/clocking_records/checkout' -Method POST -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/clocking_records/checkout' -Method POST -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("POST", "/baseUrl/clocking_records/checkout", headers=headers)

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

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

url = "{{baseUrl}}/clocking_records/checkout"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/clocking_records/checkout"

response <- VERB("POST", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/clocking_records/checkout")

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

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.post('/baseUrl/clocking_records/checkout') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

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

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/clocking_records/checkout \
  --header 'x-auth-token: {{apiKey}}'
http POST {{baseUrl}}/clocking_records/checkout \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/clocking_records/checkout
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/clocking_records/checkout")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
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 Create clocking record for authenticated user
{{baseUrl}}/clocking_records
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "checkin_latitude": "",
  "checkin_longitude": "",
  "checkout_latitude": "",
  "checkout_longitude": "",
  "project_id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\n}");

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

(client/post "{{baseUrl}}/clocking_records" {:headers {:x-auth-token "{{apiKey}}"}
                                                             :content-type :json
                                                             :form-params {:checkin_latitude ""
                                                                           :checkin_longitude ""
                                                                           :checkout_latitude ""
                                                                           :checkout_longitude ""
                                                                           :project_id ""}})
require "http/client"

url = "{{baseUrl}}/clocking_records"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\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}}/clocking_records"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\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}}/clocking_records");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/clocking_records"

	payload := strings.NewReader("{\n  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\n}")

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

	req.Header.Add("x-auth-token", "{{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/clocking_records HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 130

{
  "checkin_latitude": "",
  "checkin_longitude": "",
  "checkout_latitude": "",
  "checkout_longitude": "",
  "project_id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/clocking_records")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/clocking_records"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\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  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/clocking_records")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/clocking_records")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  checkin_latitude: '',
  checkin_longitude: '',
  checkout_latitude: '',
  checkout_longitude: '',
  project_id: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/clocking_records',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    checkin_latitude: '',
    checkin_longitude: '',
    checkout_latitude: '',
    checkout_longitude: '',
    project_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/clocking_records';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"checkin_latitude":"","checkin_longitude":"","checkout_latitude":"","checkout_longitude":"","project_id":""}'
};

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}}/clocking_records',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "checkin_latitude": "",\n  "checkin_longitude": "",\n  "checkout_latitude": "",\n  "checkout_longitude": "",\n  "project_id": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/clocking_records")
  .post(body)
  .addHeader("x-auth-token", "{{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/clocking_records',
  headers: {
    'x-auth-token': '{{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({
  checkin_latitude: '',
  checkin_longitude: '',
  checkout_latitude: '',
  checkout_longitude: '',
  project_id: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/clocking_records',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    checkin_latitude: '',
    checkin_longitude: '',
    checkout_latitude: '',
    checkout_longitude: '',
    project_id: ''
  },
  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}}/clocking_records');

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

req.type('json');
req.send({
  checkin_latitude: '',
  checkin_longitude: '',
  checkout_latitude: '',
  checkout_longitude: '',
  project_id: ''
});

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}}/clocking_records',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    checkin_latitude: '',
    checkin_longitude: '',
    checkout_latitude: '',
    checkout_longitude: '',
    project_id: ''
  }
};

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

const url = '{{baseUrl}}/clocking_records';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"checkin_latitude":"","checkin_longitude":"","checkout_latitude":"","checkout_longitude":"","project_id":""}'
};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"checkin_latitude": @"",
                              @"checkin_longitude": @"",
                              @"checkout_latitude": @"",
                              @"checkout_longitude": @"",
                              @"project_id": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/clocking_records"]
                                                       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}}/clocking_records" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/clocking_records",
  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([
    'checkin_latitude' => '',
    'checkin_longitude' => '',
    'checkout_latitude' => '',
    'checkout_longitude' => '',
    'project_id' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/clocking_records', [
  'body' => '{
  "checkin_latitude": "",
  "checkin_longitude": "",
  "checkout_latitude": "",
  "checkout_longitude": "",
  "project_id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'checkin_latitude' => '',
  'checkin_longitude' => '',
  'checkout_latitude' => '',
  'checkout_longitude' => '',
  'project_id' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'checkin_latitude' => '',
  'checkin_longitude' => '',
  'checkout_latitude' => '',
  'checkout_longitude' => '',
  'project_id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/clocking_records');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/clocking_records' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "checkin_latitude": "",
  "checkin_longitude": "",
  "checkout_latitude": "",
  "checkout_longitude": "",
  "project_id": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/clocking_records' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "checkin_latitude": "",
  "checkin_longitude": "",
  "checkout_latitude": "",
  "checkout_longitude": "",
  "project_id": ""
}'
import http.client

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

payload = "{\n  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

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

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

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

url = "{{baseUrl}}/clocking_records"

payload = {
    "checkin_latitude": "",
    "checkin_longitude": "",
    "checkout_latitude": "",
    "checkout_longitude": "",
    "project_id": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/clocking_records"

payload <- "{\n  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/clocking_records")

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

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\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/clocking_records') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"checkin_latitude\": \"\",\n  \"checkin_longitude\": \"\",\n  \"checkout_latitude\": \"\",\n  \"checkout_longitude\": \"\",\n  \"project_id\": \"\"\n}"
end

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

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

    let payload = json!({
        "checkin_latitude": "",
        "checkin_longitude": "",
        "checkout_latitude": "",
        "checkout_longitude": "",
        "project_id": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/clocking_records \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "checkin_latitude": "",
  "checkin_longitude": "",
  "checkout_latitude": "",
  "checkout_longitude": "",
  "project_id": ""
}'
echo '{
  "checkin_latitude": "",
  "checkin_longitude": "",
  "checkout_latitude": "",
  "checkout_longitude": "",
  "project_id": ""
}' |  \
  http POST {{baseUrl}}/clocking_records \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "checkin_latitude": "",\n  "checkin_longitude": "",\n  "checkout_latitude": "",\n  "checkout_longitude": "",\n  "project_id": ""\n}' \
  --output-document \
  - {{baseUrl}}/clocking_records
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "checkin_latitude": "",
  "checkin_longitude": "",
  "checkout_latitude": "",
  "checkout_longitude": "",
  "project_id": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/clocking_records")! 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 Delete a clocking record
{{baseUrl}}/clocking_records/:clocking_record_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

clocking_record_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/clocking_records/:clocking_record_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/delete "{{baseUrl}}/clocking_records/:clocking_record_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/clocking_records/:clocking_record_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/clocking_records/:clocking_record_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/clocking_records/:clocking_record_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/clocking_records/:clocking_record_id"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
DELETE /baseUrl/clocking_records/:clocking_record_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/clocking_records/:clocking_record_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/clocking_records/:clocking_record_id"))
    .header("x-auth-token", "{{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}}/clocking_records/:clocking_record_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/clocking_records/:clocking_record_id")
  .header("x-auth-token", "{{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}}/clocking_records/:clocking_record_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/clocking_records/:clocking_record_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/clocking_records/:clocking_record_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/clocking_records/:clocking_record_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/clocking_records/:clocking_record_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/clocking_records/:clocking_record_id',
  headers: {
    'x-auth-token': '{{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}}/clocking_records/:clocking_record_id',
  headers: {'x-auth-token': '{{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}}/clocking_records/:clocking_record_id');

req.headers({
  'x-auth-token': '{{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}}/clocking_records/:clocking_record_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/clocking_records/:clocking_record_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/clocking_records/:clocking_record_id"]
                                                       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}}/clocking_records/:clocking_record_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/clocking_records/:clocking_record_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/clocking_records/:clocking_record_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/clocking_records/:clocking_record_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/clocking_records/:clocking_record_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/clocking_records/:clocking_record_id' -Method DELETE -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/clocking_records/:clocking_record_id", headers=headers)

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

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

url = "{{baseUrl}}/clocking_records/:clocking_record_id"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/clocking_records/:clocking_record_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/clocking_records/:clocking_record_id")

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

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.delete('/baseUrl/clocking_records/:clocking_record_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

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

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/clocking_records/:clocking_record_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/clocking_records/:clocking_record_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/clocking_records/:clocking_record_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/clocking_records/:clocking_record_id")! 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 Details of 1 clocking_record
{{baseUrl}}/clocking_records/:clocking_record_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

clocking_record_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/clocking_records/:clocking_record_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/clocking_records/:clocking_record_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/clocking_records/:clocking_record_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/clocking_records/:clocking_record_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/clocking_records/:clocking_record_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/clocking_records/:clocking_record_id"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
GET /baseUrl/clocking_records/:clocking_record_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/clocking_records/:clocking_record_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/clocking_records/:clocking_record_id"))
    .header("x-auth-token", "{{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}}/clocking_records/:clocking_record_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/clocking_records/:clocking_record_id")
  .header("x-auth-token", "{{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}}/clocking_records/:clocking_record_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/clocking_records/:clocking_record_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/clocking_records/:clocking_record_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/clocking_records/:clocking_record_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/clocking_records/:clocking_record_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/clocking_records/:clocking_record_id',
  headers: {
    'x-auth-token': '{{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}}/clocking_records/:clocking_record_id',
  headers: {'x-auth-token': '{{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}}/clocking_records/:clocking_record_id');

req.headers({
  'x-auth-token': '{{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}}/clocking_records/:clocking_record_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/clocking_records/:clocking_record_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/clocking_records/:clocking_record_id"]
                                                       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}}/clocking_records/:clocking_record_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/clocking_records/:clocking_record_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/clocking_records/:clocking_record_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/clocking_records/:clocking_record_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/clocking_records/:clocking_record_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/clocking_records/:clocking_record_id' -Method GET -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/clocking_records/:clocking_record_id", headers=headers)

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

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

url = "{{baseUrl}}/clocking_records/:clocking_record_id"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/clocking_records/:clocking_record_id"

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

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

url = URI("{{baseUrl}}/clocking_records/:clocking_record_id")

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

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/clocking_records/:clocking_record_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/clocking_records/:clocking_record_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/clocking_records/:clocking_record_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/clocking_records/:clocking_record_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/clocking_records/:clocking_record_id")! 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 Edit a clocking record
{{baseUrl}}/clocking_records/:clocking_record_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

clocking_record_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/clocking_records/:clocking_record_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/put "{{baseUrl}}/clocking_records/:clocking_record_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/clocking_records/:clocking_record_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/clocking_records/:clocking_record_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/clocking_records/:clocking_record_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/clocking_records/:clocking_record_id"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
PUT /baseUrl/clocking_records/:clocking_record_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/clocking_records/:clocking_record_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/clocking_records/:clocking_record_id"))
    .header("x-auth-token", "{{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}}/clocking_records/:clocking_record_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/clocking_records/:clocking_record_id")
  .header("x-auth-token", "{{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}}/clocking_records/:clocking_record_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/clocking_records/:clocking_record_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/clocking_records/:clocking_record_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/clocking_records/:clocking_record_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/clocking_records/:clocking_record_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/clocking_records/:clocking_record_id',
  headers: {
    'x-auth-token': '{{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}}/clocking_records/:clocking_record_id',
  headers: {'x-auth-token': '{{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}}/clocking_records/:clocking_record_id');

req.headers({
  'x-auth-token': '{{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}}/clocking_records/:clocking_record_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/clocking_records/:clocking_record_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/clocking_records/:clocking_record_id"]
                                                       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}}/clocking_records/:clocking_record_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/clocking_records/:clocking_record_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/clocking_records/:clocking_record_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/clocking_records/:clocking_record_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/clocking_records/:clocking_record_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/clocking_records/:clocking_record_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/clocking_records/:clocking_record_id' -Method PUT -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/clocking_records/:clocking_record_id", headers=headers)

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

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

url = "{{baseUrl}}/clocking_records/:clocking_record_id"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/clocking_records/:clocking_record_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/clocking_records/:clocking_record_id")

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

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.put('/baseUrl/clocking_records/:clocking_record_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

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

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/clocking_records/:clocking_record_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/clocking_records/:clocking_record_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/clocking_records/:clocking_record_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/clocking_records/:clocking_record_id")! 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()
GET Get a list of clocking records
{{baseUrl}}/clocking_records
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/clocking_records" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/clocking_records"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/clocking_records"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/clocking_records");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/clocking_records"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
GET /baseUrl/clocking_records HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/clocking_records',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/clocking_records';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/clocking_records',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/clocking_records")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/clocking_records',
  headers: {
    'x-auth-token': '{{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}}/clocking_records',
  headers: {'x-auth-token': '{{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}}/clocking_records');

req.headers({
  'x-auth-token': '{{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}}/clocking_records',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/clocking_records';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/clocking_records"]
                                                       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}}/clocking_records" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/clocking_records', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

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

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/clocking_records');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

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

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/clocking_records", headers=headers)

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

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

url = "{{baseUrl}}/clocking_records"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/clocking_records"

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

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

url = URI("{{baseUrl}}/clocking_records")

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

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/clocking_records') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/clocking_records \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/clocking_records \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/clocking_records
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/clocking_records")! 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 a company integration feature setting
{{baseUrl}}/companies/:company_id/companies_integration_feature_settings
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
BODY json

{
  "integration_feature_setting_id": "",
  "value": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"integration_feature_setting_id\": \"\",\n  \"value\": \"\"\n}");

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

(client/post "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings" {:headers {:x-auth-token "{{apiKey}}"}
                                                                                                         :content-type :json
                                                                                                         :form-params {:integration_feature_setting_id ""
                                                                                                                       :value ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings"

	payload := strings.NewReader("{\n  \"integration_feature_setting_id\": \"\",\n  \"value\": \"\"\n}")

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

	req.Header.Add("x-auth-token", "{{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/companies/:company_id/companies_integration_feature_settings HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 57

{
  "integration_feature_setting_id": "",
  "value": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"integration_feature_setting_id\": \"\",\n  \"value\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"integration_feature_setting_id\": \"\",\n  \"value\": \"\"\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  \"integration_feature_setting_id\": \"\",\n  \"value\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"integration_feature_setting_id\": \"\",\n  \"value\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  integration_feature_setting_id: '',
  value: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {integration_feature_setting_id: '', value: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"integration_feature_setting_id":"","value":""}'
};

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}}/companies/:company_id/companies_integration_feature_settings',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "integration_feature_setting_id": "",\n  "value": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"integration_feature_setting_id\": \"\",\n  \"value\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings")
  .post(body)
  .addHeader("x-auth-token", "{{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/companies/:company_id/companies_integration_feature_settings',
  headers: {
    'x-auth-token': '{{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({integration_feature_setting_id: '', value: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {integration_feature_setting_id: '', value: ''},
  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}}/companies/:company_id/companies_integration_feature_settings');

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

req.type('json');
req.send({
  integration_feature_setting_id: '',
  value: ''
});

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}}/companies/:company_id/companies_integration_feature_settings',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {integration_feature_setting_id: '', value: ''}
};

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

const url = '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"integration_feature_setting_id":"","value":""}'
};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"integration_feature_setting_id": @"",
                              @"value": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/companies_integration_feature_settings"]
                                                       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}}/companies/:company_id/companies_integration_feature_settings" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"integration_feature_setting_id\": \"\",\n  \"value\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings",
  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([
    'integration_feature_setting_id' => '',
    'value' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings', [
  'body' => '{
  "integration_feature_setting_id": "",
  "value": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/companies_integration_feature_settings');
$request->setMethod(HTTP_METH_POST);

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

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'integration_feature_setting_id' => '',
  'value' => ''
]));
$request->setRequestUrl('{{baseUrl}}/companies/:company_id/companies_integration_feature_settings');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

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

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

payload = "{\n  \"integration_feature_setting_id\": \"\",\n  \"value\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/companies/:company_id/companies_integration_feature_settings", payload, headers)

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

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

url = "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings"

payload = {
    "integration_feature_setting_id": "",
    "value": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings"

payload <- "{\n  \"integration_feature_setting_id\": \"\",\n  \"value\": \"\"\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings")

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

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"integration_feature_setting_id\": \"\",\n  \"value\": \"\"\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/companies/:company_id/companies_integration_feature_settings') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"integration_feature_setting_id\": \"\",\n  \"value\": \"\"\n}"
end

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

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

    let payload = json!({
        "integration_feature_setting_id": "",
        "value": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/companies_integration_feature_settings \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "integration_feature_setting_id": "",
  "value": ""
}'
echo '{
  "integration_feature_setting_id": "",
  "value": ""
}' |  \
  http POST {{baseUrl}}/companies/:company_id/companies_integration_feature_settings \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "integration_feature_setting_id": "",\n  "value": ""\n}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id/companies_integration_feature_settings
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "integration_feature_setting_id": "",
  "value": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings")! 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 a company integration setting
{{baseUrl}}/companies/:company_id/integration_settings
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
BODY json

{
  "integration_setting_id": "",
  "value": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/integration_settings");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}");

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

(client/post "{{baseUrl}}/companies/:company_id/integration_settings" {:headers {:x-auth-token "{{apiKey}}"}
                                                                                       :content-type :json
                                                                                       :form-params {:integration_setting_id ""
                                                                                                     :value ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/companies/:company_id/integration_settings"

	payload := strings.NewReader("{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}")

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

	req.Header.Add("x-auth-token", "{{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/companies/:company_id/integration_settings HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 49

{
  "integration_setting_id": "",
  "value": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/companies/:company_id/integration_settings")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/integration_settings"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\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  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/integration_settings")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/companies/:company_id/integration_settings")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  integration_setting_id: '',
  value: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/companies/:company_id/integration_settings');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/companies/:company_id/integration_settings',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {integration_setting_id: '', value: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/integration_settings';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"integration_setting_id":"","value":""}'
};

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}}/companies/:company_id/integration_settings',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "integration_setting_id": "",\n  "value": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/integration_settings")
  .post(body)
  .addHeader("x-auth-token", "{{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/companies/:company_id/integration_settings',
  headers: {
    'x-auth-token': '{{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({integration_setting_id: '', value: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/companies/:company_id/integration_settings',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {integration_setting_id: '', value: ''},
  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}}/companies/:company_id/integration_settings');

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

req.type('json');
req.send({
  integration_setting_id: '',
  value: ''
});

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}}/companies/:company_id/integration_settings',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {integration_setting_id: '', value: ''}
};

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

const url = '{{baseUrl}}/companies/:company_id/integration_settings';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"integration_setting_id":"","value":""}'
};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"integration_setting_id": @"",
                              @"value": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/integration_settings"]
                                                       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}}/companies/:company_id/integration_settings" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/:company_id/integration_settings",
  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([
    'integration_setting_id' => '',
    'value' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/companies/:company_id/integration_settings', [
  'body' => '{
  "integration_setting_id": "",
  "value": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/integration_settings');
$request->setMethod(HTTP_METH_POST);

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

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'integration_setting_id' => '',
  'value' => ''
]));
$request->setRequestUrl('{{baseUrl}}/companies/:company_id/integration_settings');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

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

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

payload = "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/companies/:company_id/integration_settings", payload, headers)

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

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

url = "{{baseUrl}}/companies/:company_id/integration_settings"

payload = {
    "integration_setting_id": "",
    "value": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/companies/:company_id/integration_settings"

payload <- "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/companies/:company_id/integration_settings")

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

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\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/companies/:company_id/integration_settings') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}"
end

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

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

    let payload = json!({
        "integration_setting_id": "",
        "value": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/integration_settings \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "integration_setting_id": "",
  "value": ""
}'
echo '{
  "integration_setting_id": "",
  "value": ""
}' |  \
  http POST {{baseUrl}}/companies/:company_id/integration_settings \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "integration_setting_id": "",\n  "value": ""\n}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id/integration_settings
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "integration_setting_id": "",
  "value": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/integration_settings")! 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 a company price margin
{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
price_margins_id
BODY json

{
  "id": "",
  "value": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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\": \"\",\n  \"value\": \"\"\n}");

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

(client/post "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id" {:headers {:x-auth-token "{{apiKey}}"}
                                                                                                  :content-type :json
                                                                                                  :form-params {:id ""
                                                                                                                :value ""}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": \"\",\n  \"value\": \"\"\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}}/companies/:company_id/price_margins/:price_margins_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id\": \"\",\n  \"value\": \"\"\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}}/companies/:company_id/price_margins/:price_margins_id");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": \"\",\n  \"value\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id"

	payload := strings.NewReader("{\n  \"id\": \"\",\n  \"value\": \"\"\n}")

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

	req.Header.Add("x-auth-token", "{{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/companies/:company_id/price_margins/:price_margins_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 29

{
  "id": "",
  "value": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": \"\",\n  \"value\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"id\": \"\",\n  \"value\": \"\"\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\": \"\",\n  \"value\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id\": \"\",\n  \"value\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  id: '',
  value: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: '', value: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":"","value":""}'
};

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}}/companies/:company_id/price_margins/:price_margins_id',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": "",\n  "value": ""\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\": \"\",\n  \"value\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id")
  .post(body)
  .addHeader("x-auth-token", "{{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/companies/:company_id/price_margins/:price_margins_id',
  headers: {
    'x-auth-token': '{{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: '', value: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {id: '', value: ''},
  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}}/companies/:company_id/price_margins/:price_margins_id');

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

req.type('json');
req.send({
  id: '',
  value: ''
});

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}}/companies/:company_id/price_margins/:price_margins_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: '', value: ''}
};

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

const url = '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":"","value":""}'
};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id": @"",
                              @"value": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id"]
                                                       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}}/companies/:company_id/price_margins/:price_margins_id" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": \"\",\n  \"value\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id",
  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' => '',
    'value' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id', [
  'body' => '{
  "id": "",
  "value": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id');
$request->setMethod(HTTP_METH_POST);

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

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => '',
  'value' => ''
]));
$request->setRequestUrl('{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": "",
  "value": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": "",
  "value": ""
}'
import http.client

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

payload = "{\n  \"id\": \"\",\n  \"value\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/companies/:company_id/price_margins/:price_margins_id", payload, headers)

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

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

url = "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id"

payload = {
    "id": "",
    "value": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id"

payload <- "{\n  \"id\": \"\",\n  \"value\": \"\"\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id")

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

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": \"\",\n  \"value\": \"\"\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/companies/:company_id/price_margins/:price_margins_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"id\": \"\",\n  \"value\": \"\"\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id";

    let payload = json!({
        "id": "",
        "value": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/price_margins/:price_margins_id \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "id": "",
  "value": ""
}'
echo '{
  "id": "",
  "value": ""
}' |  \
  http POST {{baseUrl}}/companies/:company_id/price_margins/:price_margins_id \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": "",\n  "value": ""\n}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id/price_margins/:price_margins_id
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "id": "",
  "value": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id")! 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 Delete a company integration setting
{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
companies_integration_setting_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/delete "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
DELETE /baseUrl/companies/:company_id/integration_settings/:companies_integration_setting_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"))
    .header("x-auth-token", "{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")
  .header("x-auth-token", "{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id/integration_settings/:companies_integration_setting_id',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id',
  headers: {'x-auth-token': '{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id');

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"]
                                                       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}}/companies/:company_id/integration_settings/:companies_integration_setting_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id' -Method DELETE -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/companies/:company_id/integration_settings/:companies_integration_setting_id", headers=headers)

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

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

url = "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")

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

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.delete('/baseUrl/companies/:company_id/integration_settings/:companies_integration_setting_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")! 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 a company price margin
{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

price_margin_id
company_id
price_margins_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/delete "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id" {:headers {:x-auth-token "{{apiKey}}"}
                                                                                                    :query-params {:price_margin_id ""}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id="
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id="),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id="

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
DELETE /baseUrl/companies/:company_id/price_margins/:price_margins_id?price_margin_id= HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id="))
    .header("x-auth-token", "{{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}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=")
  .header("x-auth-token", "{{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}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id',
  params: {price_margin_id: ''},
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id/price_margins/:price_margins_id?price_margin_id=',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id/price_margins/:price_margins_id',
  qs: {price_margin_id: ''},
  headers: {'x-auth-token': '{{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}}/companies/:company_id/price_margins/:price_margins_id');

req.query({
  price_margin_id: ''
});

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id/price_margins/:price_margins_id',
  params: {price_margin_id: ''},
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id="]
                                                       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}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setQueryData([
  'price_margin_id' => ''
]);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id');
$request->setRequestMethod('DELETE');
$request->setQuery(new http\QueryString([
  'price_margin_id' => ''
]));

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=' -Method DELETE -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/companies/:company_id/price_margins/:price_margins_id?price_margin_id=", headers=headers)

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

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

url = "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id"

querystring = {"price_margin_id":""}

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers, params=querystring)

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

url <- "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id"

queryString <- list(price_margin_id = "")

response <- VERB("DELETE", url, query = queryString, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=")

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

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.delete('/baseUrl/companies/:company_id/price_margins/:price_margins_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.params['price_margin_id'] = ''
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id";

    let querystring = [
        ("price_margin_id", ""),
    ];

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

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

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

    dbg!(results);
}
curl --request DELETE \
  --url '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=' \
  --header 'x-auth-token: {{apiKey}}'
http DELETE '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=' \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id='
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id?price_margin_id=")! 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 a form template company
{{baseUrl}}/companies/:company_id/form_templates/:form_template_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
form_template_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/delete "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id/form_templates/:form_template_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id/form_templates/:form_template_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
DELETE /baseUrl/companies/:company_id/form_templates/:form_template_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/form_templates/:form_template_id"))
    .header("x-auth-token", "{{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}}/companies/:company_id/form_templates/:form_template_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/companies/:company_id/form_templates/:form_template_id")
  .header("x-auth-token", "{{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}}/companies/:company_id/form_templates/:form_template_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/companies/:company_id/form_templates/:form_template_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/form_templates/:form_template_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/companies/:company_id/form_templates/:form_template_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/form_templates/:form_template_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id/form_templates/:form_template_id',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id/form_templates/:form_template_id',
  headers: {'x-auth-token': '{{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}}/companies/:company_id/form_templates/:form_template_id');

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id/form_templates/:form_template_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/companies/:company_id/form_templates/:form_template_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/form_templates/:form_template_id"]
                                                       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}}/companies/:company_id/form_templates/:form_template_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/companies/:company_id/form_templates/:form_template_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/form_templates/:form_template_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id/form_templates/:form_template_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/form_templates/:form_template_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/form_templates/:form_template_id' -Method DELETE -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/companies/:company_id/form_templates/:form_template_id", headers=headers)

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

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

url = "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/companies/:company_id/form_templates/:form_template_id")

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

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.delete('/baseUrl/companies/:company_id/form_templates/:form_template_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/form_templates/:form_template_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/companies/:company_id/form_templates/:form_template_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id/form_templates/:form_template_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id")! 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 Details of 1 company
{{baseUrl}}/companies/:company_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/companies/:company_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/companies/:company_id"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
GET /baseUrl/companies/:company_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/companies/:company_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id"))
    .header("x-auth-token", "{{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}}/companies/:company_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/companies/:company_id")
  .header("x-auth-token", "{{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}}/companies/:company_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies/:company_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies/:company_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id',
  headers: {'x-auth-token': '{{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}}/companies/:company_id');

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/companies/:company_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id"]
                                                       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}}/companies/:company_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies/:company_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id' -Method GET -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies/:company_id", headers=headers)

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

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

url = "{{baseUrl}}/companies/:company_id"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/companies/:company_id"

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

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

url = URI("{{baseUrl}}/companies/:company_id")

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

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/companies/:company_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/companies/:company_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id")! 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 Edit a company integration feature setting
{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
c_integration_feature_setting_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/put "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
PUT /baseUrl/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id"))
    .header("x-auth-token", "{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id")
  .header("x-auth-token", "{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id',
  headers: {'x-auth-token': '{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id');

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id"]
                                                       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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id' -Method PUT -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id", headers=headers)

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

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

url = "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id")

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

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.put('/baseUrl/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id")! 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 Edit a company integration setting
{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
companies_integration_setting_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/put "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
PUT /baseUrl/companies/:company_id/integration_settings/:companies_integration_setting_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"))
    .header("x-auth-token", "{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")
  .header("x-auth-token", "{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id/integration_settings/:companies_integration_setting_id',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id',
  headers: {'x-auth-token': '{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id');

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"]
                                                       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}}/companies/:company_id/integration_settings/:companies_integration_setting_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id' -Method PUT -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/companies/:company_id/integration_settings/:companies_integration_setting_id", headers=headers)

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

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

url = "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")

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

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.put('/baseUrl/companies/:company_id/integration_settings/:companies_integration_setting_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")! 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()
GET Get a company form template
{{baseUrl}}/companies/:company_id/form_templates/:form_template_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

id
company_id
form_template_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id" {:headers {:x-auth-token "{{apiKey}}"}
                                                                                                  :query-params {:id ""}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id="
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id/form_templates/:form_template_id?id="),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id=");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id="

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
GET /baseUrl/companies/:company_id/form_templates/:form_template_id?id= HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id=")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id="))
    .header("x-auth-token", "{{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}}/companies/:company_id/form_templates/:form_template_id?id=")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id=")
  .header("x-auth-token", "{{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}}/companies/:company_id/form_templates/:form_template_id?id=');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies/:company_id/form_templates/:form_template_id',
  params: {id: ''},
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id=';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies/:company_id/form_templates/:form_template_id?id=',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id=")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id/form_templates/:form_template_id?id=',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id/form_templates/:form_template_id',
  qs: {id: ''},
  headers: {'x-auth-token': '{{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}}/companies/:company_id/form_templates/:form_template_id');

req.query({
  id: ''
});

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id/form_templates/:form_template_id',
  params: {id: ''},
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id=';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id="]
                                                       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}}/companies/:company_id/form_templates/:form_template_id?id=" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id=', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/form_templates/:form_template_id');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'id' => ''
]);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id/form_templates/:form_template_id');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'id' => ''
]));

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id=' -Method GET -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies/:company_id/form_templates/:form_template_id?id=", headers=headers)

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

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

url = "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id"

querystring = {"id":""}

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id"

queryString <- list(id = "")

response <- VERB("GET", url, query = queryString, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id=")

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

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/companies/:company_id/form_templates/:form_template_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.params['id'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id";

    let querystring = [
        ("id", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/form_templates/:form_template_id?id=' \
  --header 'x-auth-token: {{apiKey}}'
http GET '{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id=' \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id='
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/form_templates/:form_template_id?id=")! 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 a company integration setting
{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
companies_integration_setting_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
GET /baseUrl/companies/:company_id/integration_settings/:companies_integration_setting_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"))
    .header("x-auth-token", "{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")
  .header("x-auth-token", "{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id/integration_settings/:companies_integration_setting_id',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id',
  headers: {'x-auth-token': '{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id');

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"]
                                                       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}}/companies/:company_id/integration_settings/:companies_integration_setting_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id' -Method GET -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies/:company_id/integration_settings/:companies_integration_setting_id", headers=headers)

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

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

url = "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id"

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

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

url = URI("{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")

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

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/companies/:company_id/integration_settings/:companies_integration_setting_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/integration_settings/:companies_integration_setting_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/integration_settings/:companies_integration_setting_id")! 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 a list of companies
{{baseUrl}}/companies
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/companies" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/companies"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
GET /baseUrl/companies HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/companies")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies',
  headers: {
    'x-auth-token': '{{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}}/companies',
  headers: {'x-auth-token': '{{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}}/companies');

req.headers({
  'x-auth-token': '{{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}}/companies',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/companies';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies"]
                                                       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}}/companies" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

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

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

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

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies", headers=headers)

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

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

url = "{{baseUrl}}/companies"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/companies"

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

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

url = URI("{{baseUrl}}/companies")

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

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/companies') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/companies \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies")! 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 a list of company form templates
{{baseUrl}}/companies/:company_id/form_templates/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

form_template_id
company_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/form_templates/?form_template_id=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/companies/:company_id/form_templates/" {:headers {:x-auth-token "{{apiKey}}"}
                                                                                 :query-params {:form_template_id ""}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/form_templates/?form_template_id="
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id/form_templates/?form_template_id="),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id/form_templates/?form_template_id=");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/companies/:company_id/form_templates/?form_template_id="

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
GET /baseUrl/companies/:company_id/form_templates/?form_template_id= HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/companies/:company_id/form_templates/?form_template_id=")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/form_templates/?form_template_id="))
    .header("x-auth-token", "{{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}}/companies/:company_id/form_templates/?form_template_id=")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/companies/:company_id/form_templates/?form_template_id=")
  .header("x-auth-token", "{{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}}/companies/:company_id/form_templates/?form_template_id=');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies/:company_id/form_templates/',
  params: {form_template_id: ''},
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/form_templates/?form_template_id=';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies/:company_id/form_templates/?form_template_id=',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/form_templates/?form_template_id=")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id/form_templates/?form_template_id=',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id/form_templates/',
  qs: {form_template_id: ''},
  headers: {'x-auth-token': '{{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}}/companies/:company_id/form_templates/');

req.query({
  form_template_id: ''
});

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id/form_templates/',
  params: {form_template_id: ''},
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/companies/:company_id/form_templates/?form_template_id=';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/form_templates/?form_template_id="]
                                                       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}}/companies/:company_id/form_templates/?form_template_id=" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/:company_id/form_templates/?form_template_id=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies/:company_id/form_templates/?form_template_id=', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/form_templates/');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'form_template_id' => ''
]);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id/form_templates/');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'form_template_id' => ''
]));

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/form_templates/?form_template_id=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/form_templates/?form_template_id=' -Method GET -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies/:company_id/form_templates/?form_template_id=", headers=headers)

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

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

url = "{{baseUrl}}/companies/:company_id/form_templates/"

querystring = {"form_template_id":""}

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/companies/:company_id/form_templates/"

queryString <- list(form_template_id = "")

response <- VERB("GET", url, query = queryString, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/companies/:company_id/form_templates/?form_template_id=")

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

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/companies/:company_id/form_templates/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.params['form_template_id'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let querystring = [
        ("form_template_id", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/form_templates/?form_template_id=' \
  --header 'x-auth-token: {{apiKey}}'
http GET '{{baseUrl}}/companies/:company_id/form_templates/?form_template_id=' \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/companies/:company_id/form_templates/?form_template_id='
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/form_templates/?form_template_id=")! 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 a list of company integration settings
{{baseUrl}}/companies/:company_id/integration_settings
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/integration_settings");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/companies/:company_id/integration_settings" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/integration_settings"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id/integration_settings"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id/integration_settings");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/companies/:company_id/integration_settings"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
GET /baseUrl/companies/:company_id/integration_settings HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/companies/:company_id/integration_settings")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/integration_settings"))
    .header("x-auth-token", "{{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}}/companies/:company_id/integration_settings")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/companies/:company_id/integration_settings")
  .header("x-auth-token", "{{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}}/companies/:company_id/integration_settings');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies/:company_id/integration_settings',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/integration_settings';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies/:company_id/integration_settings',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/integration_settings")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id/integration_settings',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id/integration_settings',
  headers: {'x-auth-token': '{{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}}/companies/:company_id/integration_settings');

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id/integration_settings',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/companies/:company_id/integration_settings';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/integration_settings"]
                                                       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}}/companies/:company_id/integration_settings" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies/:company_id/integration_settings', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/integration_settings');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id/integration_settings');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/integration_settings' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/integration_settings' -Method GET -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies/:company_id/integration_settings", headers=headers)

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

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

url = "{{baseUrl}}/companies/:company_id/integration_settings"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/companies/:company_id/integration_settings"

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

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

url = URI("{{baseUrl}}/companies/:company_id/integration_settings")

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

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

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

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

response = conn.get('/baseUrl/companies/:company_id/integration_settings') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/integration_settings \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/companies/:company_id/integration_settings \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id/integration_settings
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/integration_settings")! 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 a list of company price margins
{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
price_margins_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id/price_margins/:price_margins_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id"

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

	req.Header.Add("x-auth-token", "{{apiKey}}")

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

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

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

}
GET /baseUrl/companies/:company_id/price_margins/:price_margins_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id"))
    .header("x-auth-token", "{{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}}/companies/:company_id/price_margins/:price_margins_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id")
  .header("x-auth-token", "{{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}}/companies/:company_id/price_margins/:price_margins_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies/:company_id/price_margins/:price_margins_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id/price_margins/:price_margins_id',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id/price_margins/:price_margins_id',
  headers: {'x-auth-token': '{{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}}/companies/:company_id/price_margins/:price_margins_id');

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id/price_margins/:price_margins_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

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

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id"]
                                                       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}}/companies/:company_id/price_margins/:price_margins_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id' -Method GET -Headers $headers
import http.client

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

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies/:company_id/price_margins/:price_margins_id", headers=headers)

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

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

url = "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id"

headers = {"x-auth-token": "{{apiKey}}"}

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

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

url <- "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id"

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

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

url = URI("{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id")

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

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/companies/:company_id/price_margins/:price_margins_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/price_margins/:price_margins_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/companies/:company_id/price_margins/:price_margins_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id/price_margins/:price_margins_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/price_margins/:price_margins_id")! 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 a list of integration feature settings
{{baseUrl}}/companies/:company_id/integration_feature_settings
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/integration_feature_settings");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/companies/:company_id/integration_feature_settings" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/integration_feature_settings"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id/integration_feature_settings"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id/integration_feature_settings");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/companies/:company_id/integration_feature_settings"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/companies/:company_id/integration_feature_settings HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/companies/:company_id/integration_feature_settings")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/integration_feature_settings"))
    .header("x-auth-token", "{{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}}/companies/:company_id/integration_feature_settings")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/companies/:company_id/integration_feature_settings")
  .header("x-auth-token", "{{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}}/companies/:company_id/integration_feature_settings');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies/:company_id/integration_feature_settings',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/integration_feature_settings';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies/:company_id/integration_feature_settings',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/integration_feature_settings")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id/integration_feature_settings',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id/integration_feature_settings',
  headers: {'x-auth-token': '{{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}}/companies/:company_id/integration_feature_settings');

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id/integration_feature_settings',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/companies/:company_id/integration_feature_settings';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/integration_feature_settings"]
                                                       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}}/companies/:company_id/integration_feature_settings" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/:company_id/integration_feature_settings",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies/:company_id/integration_feature_settings', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/integration_feature_settings');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id/integration_feature_settings');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/integration_feature_settings' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/integration_feature_settings' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies/:company_id/integration_feature_settings", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/companies/:company_id/integration_feature_settings"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/companies/:company_id/integration_feature_settings"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/companies/:company_id/integration_feature_settings")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/companies/:company_id/integration_feature_settings') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies/:company_id/integration_feature_settings";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/integration_feature_settings \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/companies/:company_id/integration_feature_settings \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id/integration_feature_settings
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/integration_feature_settings")! 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 a company integration feature settings
{{baseUrl}}/companies/:company_id/companies_integration_feature_settings
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id/companies_integration_feature_settings"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/companies/:company_id/companies_integration_feature_settings HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings"))
    .header("x-auth-token", "{{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}}/companies/:company_id/companies_integration_feature_settings")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings")
  .header("x-auth-token", "{{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}}/companies/:company_id/companies_integration_feature_settings');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies/:company_id/companies_integration_feature_settings',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id/companies_integration_feature_settings',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id/companies_integration_feature_settings',
  headers: {'x-auth-token': '{{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}}/companies/:company_id/companies_integration_feature_settings');

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id/companies_integration_feature_settings',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/companies_integration_feature_settings"]
                                                       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}}/companies/:company_id/companies_integration_feature_settings" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/companies_integration_feature_settings');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id/companies_integration_feature_settings');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies/:company_id/companies_integration_feature_settings", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/companies/:company_id/companies_integration_feature_settings') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/companies_integration_feature_settings \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/companies/:company_id/companies_integration_feature_settings \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id/companies_integration_feature_settings
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings")! 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 Show details of 1 integration feature setting
{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
integration_feature_setting_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/companies/:company_id/integration_feature_settings/:integration_feature_setting_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id"))
    .header("x-auth-token", "{{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}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id")
  .header("x-auth-token", "{{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}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id/integration_feature_settings/:integration_feature_setting_id',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id',
  headers: {'x-auth-token': '{{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}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id');

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id"]
                                                       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}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies/:company_id/integration_feature_settings/:integration_feature_setting_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/companies/:company_id/integration_feature_settings/:integration_feature_setting_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/integration_feature_settings/:integration_feature_setting_id")! 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 URL for subscription selfservice
{{baseUrl}}/companies/subscription_self_service
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/subscription_self_service");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/companies/subscription_self_service" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies/subscription_self_service"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/subscription_self_service"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/subscription_self_service");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/companies/subscription_self_service"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/companies/subscription_self_service HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/companies/subscription_self_service")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/subscription_self_service"))
    .header("x-auth-token", "{{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}}/companies/subscription_self_service")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/companies/subscription_self_service")
  .header("x-auth-token", "{{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}}/companies/subscription_self_service');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies/subscription_self_service',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/subscription_self_service';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies/subscription_self_service',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/companies/subscription_self_service")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/subscription_self_service',
  headers: {
    'x-auth-token': '{{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}}/companies/subscription_self_service',
  headers: {'x-auth-token': '{{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}}/companies/subscription_self_service');

req.headers({
  'x-auth-token': '{{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}}/companies/subscription_self_service',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/companies/subscription_self_service';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/subscription_self_service"]
                                                       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}}/companies/subscription_self_service" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/subscription_self_service",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies/subscription_self_service', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/subscription_self_service');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/subscription_self_service');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/subscription_self_service' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/subscription_self_service' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies/subscription_self_service", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/companies/subscription_self_service"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/companies/subscription_self_service"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/companies/subscription_self_service")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/companies/subscription_self_service') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies/subscription_self_service";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/subscription_self_service \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/companies/subscription_self_service \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies/subscription_self_service
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/subscription_self_service")! 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 View a company integration feature setting
{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

company_id
c_integration_feature_setting_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id"))
    .header("x-auth-token", "{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id")
  .header("x-auth-token", "{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id',
  headers: {
    'x-auth-token': '{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id',
  headers: {'x-auth-token': '{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id');

req.headers({
  'x-auth-token': '{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id"]
                                                       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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies/:company_id/companies_integration_feature_settings/:c_integration_feature_setting_id")! 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 a new companies vendor
{{baseUrl}}/companies_vendors
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies_vendors");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/companies_vendors" {:headers {:x-auth-token "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:company_id ""
                                                                            :delivery_price ""
                                                                            :free_delivery_price ""
                                                                            :is_active false
                                                                            :password ""
                                                                            :receive_automatic_price_files false
                                                                            :receive_invoice_mails false
                                                                            :reviewed false
                                                                            :use_price_files false
                                                                            :username ""
                                                                            :vendor_account_reference ""
                                                                            :vendor_department_id ""
                                                                            :vendor_email ""
                                                                            :vendor_id ""
                                                                            :vendor_name ""}})
require "http/client"

url = "{{baseUrl}}/companies_vendors"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_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}}/companies_vendors"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_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}}/companies_vendors");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/companies_vendors"

	payload := strings.NewReader("{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/companies_vendors HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 384

{
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/companies_vendors")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies_vendors"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_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  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/companies_vendors")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/companies_vendors")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  company_id: '',
  delivery_price: '',
  free_delivery_price: '',
  is_active: false,
  password: '',
  receive_automatic_price_files: false,
  receive_invoice_mails: false,
  reviewed: false,
  use_price_files: false,
  username: '',
  vendor_account_reference: '',
  vendor_department_id: '',
  vendor_email: '',
  vendor_id: '',
  vendor_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}}/companies_vendors');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/companies_vendors',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    company_id: '',
    delivery_price: '',
    free_delivery_price: '',
    is_active: false,
    password: '',
    receive_automatic_price_files: false,
    receive_invoice_mails: false,
    reviewed: false,
    use_price_files: false,
    username: '',
    vendor_account_reference: '',
    vendor_department_id: '',
    vendor_email: '',
    vendor_id: '',
    vendor_name: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies_vendors';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"company_id":"","delivery_price":"","free_delivery_price":"","is_active":false,"password":"","receive_automatic_price_files":false,"receive_invoice_mails":false,"reviewed":false,"use_price_files":false,"username":"","vendor_account_reference":"","vendor_department_id":"","vendor_email":"","vendor_id":"","vendor_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}}/companies_vendors',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "company_id": "",\n  "delivery_price": "",\n  "free_delivery_price": "",\n  "is_active": false,\n  "password": "",\n  "receive_automatic_price_files": false,\n  "receive_invoice_mails": false,\n  "reviewed": false,\n  "use_price_files": false,\n  "username": "",\n  "vendor_account_reference": "",\n  "vendor_department_id": "",\n  "vendor_email": "",\n  "vendor_id": "",\n  "vendor_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  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/companies_vendors")
  .post(body)
  .addHeader("x-auth-token", "{{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/companies_vendors',
  headers: {
    'x-auth-token': '{{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({
  company_id: '',
  delivery_price: '',
  free_delivery_price: '',
  is_active: false,
  password: '',
  receive_automatic_price_files: false,
  receive_invoice_mails: false,
  reviewed: false,
  use_price_files: false,
  username: '',
  vendor_account_reference: '',
  vendor_department_id: '',
  vendor_email: '',
  vendor_id: '',
  vendor_name: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/companies_vendors',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    company_id: '',
    delivery_price: '',
    free_delivery_price: '',
    is_active: false,
    password: '',
    receive_automatic_price_files: false,
    receive_invoice_mails: false,
    reviewed: false,
    use_price_files: false,
    username: '',
    vendor_account_reference: '',
    vendor_department_id: '',
    vendor_email: '',
    vendor_id: '',
    vendor_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}}/companies_vendors');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  company_id: '',
  delivery_price: '',
  free_delivery_price: '',
  is_active: false,
  password: '',
  receive_automatic_price_files: false,
  receive_invoice_mails: false,
  reviewed: false,
  use_price_files: false,
  username: '',
  vendor_account_reference: '',
  vendor_department_id: '',
  vendor_email: '',
  vendor_id: '',
  vendor_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}}/companies_vendors',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    company_id: '',
    delivery_price: '',
    free_delivery_price: '',
    is_active: false,
    password: '',
    receive_automatic_price_files: false,
    receive_invoice_mails: false,
    reviewed: false,
    use_price_files: false,
    username: '',
    vendor_account_reference: '',
    vendor_department_id: '',
    vendor_email: '',
    vendor_id: '',
    vendor_name: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/companies_vendors';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"company_id":"","delivery_price":"","free_delivery_price":"","is_active":false,"password":"","receive_automatic_price_files":false,"receive_invoice_mails":false,"reviewed":false,"use_price_files":false,"username":"","vendor_account_reference":"","vendor_department_id":"","vendor_email":"","vendor_id":"","vendor_name":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"company_id": @"",
                              @"delivery_price": @"",
                              @"free_delivery_price": @"",
                              @"is_active": @NO,
                              @"password": @"",
                              @"receive_automatic_price_files": @NO,
                              @"receive_invoice_mails": @NO,
                              @"reviewed": @NO,
                              @"use_price_files": @NO,
                              @"username": @"",
                              @"vendor_account_reference": @"",
                              @"vendor_department_id": @"",
                              @"vendor_email": @"",
                              @"vendor_id": @"",
                              @"vendor_name": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies_vendors"]
                                                       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}}/companies_vendors" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies_vendors",
  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([
    'company_id' => '',
    'delivery_price' => '',
    'free_delivery_price' => '',
    'is_active' => null,
    'password' => '',
    'receive_automatic_price_files' => null,
    'receive_invoice_mails' => null,
    'reviewed' => null,
    'use_price_files' => null,
    'username' => '',
    'vendor_account_reference' => '',
    'vendor_department_id' => '',
    'vendor_email' => '',
    'vendor_id' => '',
    'vendor_name' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/companies_vendors', [
  'body' => '{
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies_vendors');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'company_id' => '',
  'delivery_price' => '',
  'free_delivery_price' => '',
  'is_active' => null,
  'password' => '',
  'receive_automatic_price_files' => null,
  'receive_invoice_mails' => null,
  'reviewed' => null,
  'use_price_files' => null,
  'username' => '',
  'vendor_account_reference' => '',
  'vendor_department_id' => '',
  'vendor_email' => '',
  'vendor_id' => '',
  'vendor_name' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'company_id' => '',
  'delivery_price' => '',
  'free_delivery_price' => '',
  'is_active' => null,
  'password' => '',
  'receive_automatic_price_files' => null,
  'receive_invoice_mails' => null,
  'reviewed' => null,
  'use_price_files' => null,
  'username' => '',
  'vendor_account_reference' => '',
  'vendor_department_id' => '',
  'vendor_email' => '',
  'vendor_id' => '',
  'vendor_name' => ''
]));
$request->setRequestUrl('{{baseUrl}}/companies_vendors');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies_vendors' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies_vendors' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/companies_vendors", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/companies_vendors"

payload = {
    "company_id": "",
    "delivery_price": "",
    "free_delivery_price": "",
    "is_active": False,
    "password": "",
    "receive_automatic_price_files": False,
    "receive_invoice_mails": False,
    "reviewed": False,
    "use_price_files": False,
    "username": "",
    "vendor_account_reference": "",
    "vendor_department_id": "",
    "vendor_email": "",
    "vendor_id": "",
    "vendor_name": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/companies_vendors"

payload <- "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/companies_vendors")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_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/companies_vendors') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies_vendors";

    let payload = json!({
        "company_id": "",
        "delivery_price": "",
        "free_delivery_price": "",
        "is_active": false,
        "password": "",
        "receive_automatic_price_files": false,
        "receive_invoice_mails": false,
        "reviewed": false,
        "use_price_files": false,
        "username": "",
        "vendor_account_reference": "",
        "vendor_department_id": "",
        "vendor_email": "",
        "vendor_id": "",
        "vendor_name": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies_vendors \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
}'
echo '{
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
}' |  \
  http POST {{baseUrl}}/companies_vendors \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "company_id": "",\n  "delivery_price": "",\n  "free_delivery_price": "",\n  "is_active": false,\n  "password": "",\n  "receive_automatic_price_files": false,\n  "receive_invoice_mails": false,\n  "reviewed": false,\n  "use_price_files": false,\n  "username": "",\n  "vendor_account_reference": "",\n  "vendor_department_id": "",\n  "vendor_email": "",\n  "vendor_id": "",\n  "vendor_name": ""\n}' \
  --output-document \
  - {{baseUrl}}/companies_vendors
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies_vendors")! 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 Bulk delete companies vendors
{{baseUrl}}/companies_vendors/bulkDelete
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies_vendors/bulkDelete");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/companies_vendors/bulkDelete" {:headers {:x-auth-token "{{apiKey}}"}
                                                                           :content-type :json
                                                                           :form-params {:id []}})
require "http/client"

url = "{{baseUrl}}/companies_vendors/bulkDelete"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": []\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}}/companies_vendors/bulkDelete"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id\": []\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}}/companies_vendors/bulkDelete");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/companies_vendors/bulkDelete"

	payload := strings.NewReader("{\n  \"id\": []\n}")

	req, _ := http.NewRequest("DELETE", url, payload)

	req.Header.Add("x-auth-token", "{{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/companies_vendors/bulkDelete HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/companies_vendors/bulkDelete")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies_vendors/bulkDelete"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"id\": []\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\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/companies_vendors/bulkDelete")
  .delete(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/companies_vendors/bulkDelete")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/companies_vendors/bulkDelete');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/companies_vendors/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies_vendors/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/companies_vendors/bulkDelete',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/companies_vendors/bulkDelete")
  .delete(body)
  .addHeader("x-auth-token", "{{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/companies_vendors/bulkDelete',
  headers: {
    'x-auth-token': '{{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: []}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/companies_vendors/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {id: []},
  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}}/companies_vendors/bulkDelete');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: []
});

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}}/companies_vendors/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/companies_vendors/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies_vendors/bulkDelete"]
                                                       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}}/companies_vendors/bulkDelete" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": []\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies_vendors/bulkDelete",
  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([
    'id' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/companies_vendors/bulkDelete', [
  'body' => '{
  "id": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies_vendors/bulkDelete');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/companies_vendors/bulkDelete');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies_vendors/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies_vendors/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": []\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("DELETE", "/baseUrl/companies_vendors/bulkDelete", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/companies_vendors/bulkDelete"

payload = { "id": [] }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/companies_vendors/bulkDelete"

payload <- "{\n  \"id\": []\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/companies_vendors/bulkDelete")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/companies_vendors/bulkDelete') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"id\": []\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}}/companies_vendors/bulkDelete";

    let payload = json!({"id": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies_vendors/bulkDelete \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http DELETE {{baseUrl}}/companies_vendors/bulkDelete \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/companies_vendors/bulkDelete
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies_vendors/bulkDelete")! 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 a companies vendor
{{baseUrl}}/companies_vendors/:companies_vendor_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

companies_vendor_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies_vendors/:companies_vendor_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/companies_vendors/:companies_vendor_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies_vendors/:companies_vendor_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies_vendors/:companies_vendor_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies_vendors/:companies_vendor_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/companies_vendors/:companies_vendor_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/companies_vendors/:companies_vendor_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/companies_vendors/:companies_vendor_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies_vendors/:companies_vendor_id"))
    .header("x-auth-token", "{{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}}/companies_vendors/:companies_vendor_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/companies_vendors/:companies_vendor_id")
  .header("x-auth-token", "{{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}}/companies_vendors/:companies_vendor_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/companies_vendors/:companies_vendor_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies_vendors/:companies_vendor_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/companies_vendors/:companies_vendor_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/companies_vendors/:companies_vendor_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies_vendors/:companies_vendor_id',
  headers: {
    'x-auth-token': '{{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}}/companies_vendors/:companies_vendor_id',
  headers: {'x-auth-token': '{{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}}/companies_vendors/:companies_vendor_id');

req.headers({
  'x-auth-token': '{{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}}/companies_vendors/:companies_vendor_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/companies_vendors/:companies_vendor_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies_vendors/:companies_vendor_id"]
                                                       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}}/companies_vendors/:companies_vendor_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies_vendors/:companies_vendor_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/companies_vendors/:companies_vendor_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies_vendors/:companies_vendor_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies_vendors/:companies_vendor_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies_vendors/:companies_vendor_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies_vendors/:companies_vendor_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/companies_vendors/:companies_vendor_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/companies_vendors/:companies_vendor_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/companies_vendors/:companies_vendor_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/companies_vendors/:companies_vendor_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/companies_vendors/:companies_vendor_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies_vendors/:companies_vendor_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies_vendors/:companies_vendor_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/companies_vendors/:companies_vendor_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies_vendors/:companies_vendor_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies_vendors/:companies_vendor_id")! 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()
PUT Edit a companies vendor
{{baseUrl}}/companies_vendors/:companies_vendor_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

companies_vendor_id
BODY json

{
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies_vendors/:companies_vendor_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/companies_vendors/:companies_vendor_id" {:headers {:x-auth-token "{{apiKey}}"}
                                                                                  :content-type :json
                                                                                  :form-params {:company_id ""
                                                                                                :delivery_price ""
                                                                                                :free_delivery_price ""
                                                                                                :is_active false
                                                                                                :password ""
                                                                                                :receive_automatic_price_files false
                                                                                                :receive_invoice_mails false
                                                                                                :reviewed false
                                                                                                :use_price_files false
                                                                                                :username ""
                                                                                                :vendor_account_reference ""
                                                                                                :vendor_department_id ""
                                                                                                :vendor_email ""
                                                                                                :vendor_id ""
                                                                                                :vendor_name ""}})
require "http/client"

url = "{{baseUrl}}/companies_vendors/:companies_vendor_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_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}}/companies_vendors/:companies_vendor_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_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}}/companies_vendors/:companies_vendor_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/companies_vendors/:companies_vendor_id"

	payload := strings.NewReader("{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("x-auth-token", "{{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/companies_vendors/:companies_vendor_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 384

{
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/companies_vendors/:companies_vendor_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies_vendors/:companies_vendor_id"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_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  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/companies_vendors/:companies_vendor_id")
  .put(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/companies_vendors/:companies_vendor_id")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  company_id: '',
  delivery_price: '',
  free_delivery_price: '',
  is_active: false,
  password: '',
  receive_automatic_price_files: false,
  receive_invoice_mails: false,
  reviewed: false,
  use_price_files: false,
  username: '',
  vendor_account_reference: '',
  vendor_department_id: '',
  vendor_email: '',
  vendor_id: '',
  vendor_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}}/companies_vendors/:companies_vendor_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/companies_vendors/:companies_vendor_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    company_id: '',
    delivery_price: '',
    free_delivery_price: '',
    is_active: false,
    password: '',
    receive_automatic_price_files: false,
    receive_invoice_mails: false,
    reviewed: false,
    use_price_files: false,
    username: '',
    vendor_account_reference: '',
    vendor_department_id: '',
    vendor_email: '',
    vendor_id: '',
    vendor_name: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies_vendors/:companies_vendor_id';
const options = {
  method: 'PUT',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"company_id":"","delivery_price":"","free_delivery_price":"","is_active":false,"password":"","receive_automatic_price_files":false,"receive_invoice_mails":false,"reviewed":false,"use_price_files":false,"username":"","vendor_account_reference":"","vendor_department_id":"","vendor_email":"","vendor_id":"","vendor_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}}/companies_vendors/:companies_vendor_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "company_id": "",\n  "delivery_price": "",\n  "free_delivery_price": "",\n  "is_active": false,\n  "password": "",\n  "receive_automatic_price_files": false,\n  "receive_invoice_mails": false,\n  "reviewed": false,\n  "use_price_files": false,\n  "username": "",\n  "vendor_account_reference": "",\n  "vendor_department_id": "",\n  "vendor_email": "",\n  "vendor_id": "",\n  "vendor_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  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/companies_vendors/:companies_vendor_id")
  .put(body)
  .addHeader("x-auth-token", "{{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/companies_vendors/:companies_vendor_id',
  headers: {
    'x-auth-token': '{{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({
  company_id: '',
  delivery_price: '',
  free_delivery_price: '',
  is_active: false,
  password: '',
  receive_automatic_price_files: false,
  receive_invoice_mails: false,
  reviewed: false,
  use_price_files: false,
  username: '',
  vendor_account_reference: '',
  vendor_department_id: '',
  vendor_email: '',
  vendor_id: '',
  vendor_name: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/companies_vendors/:companies_vendor_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    company_id: '',
    delivery_price: '',
    free_delivery_price: '',
    is_active: false,
    password: '',
    receive_automatic_price_files: false,
    receive_invoice_mails: false,
    reviewed: false,
    use_price_files: false,
    username: '',
    vendor_account_reference: '',
    vendor_department_id: '',
    vendor_email: '',
    vendor_id: '',
    vendor_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}}/companies_vendors/:companies_vendor_id');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  company_id: '',
  delivery_price: '',
  free_delivery_price: '',
  is_active: false,
  password: '',
  receive_automatic_price_files: false,
  receive_invoice_mails: false,
  reviewed: false,
  use_price_files: false,
  username: '',
  vendor_account_reference: '',
  vendor_department_id: '',
  vendor_email: '',
  vendor_id: '',
  vendor_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}}/companies_vendors/:companies_vendor_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    company_id: '',
    delivery_price: '',
    free_delivery_price: '',
    is_active: false,
    password: '',
    receive_automatic_price_files: false,
    receive_invoice_mails: false,
    reviewed: false,
    use_price_files: false,
    username: '',
    vendor_account_reference: '',
    vendor_department_id: '',
    vendor_email: '',
    vendor_id: '',
    vendor_name: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/companies_vendors/:companies_vendor_id';
const options = {
  method: 'PUT',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"company_id":"","delivery_price":"","free_delivery_price":"","is_active":false,"password":"","receive_automatic_price_files":false,"receive_invoice_mails":false,"reviewed":false,"use_price_files":false,"username":"","vendor_account_reference":"","vendor_department_id":"","vendor_email":"","vendor_id":"","vendor_name":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"company_id": @"",
                              @"delivery_price": @"",
                              @"free_delivery_price": @"",
                              @"is_active": @NO,
                              @"password": @"",
                              @"receive_automatic_price_files": @NO,
                              @"receive_invoice_mails": @NO,
                              @"reviewed": @NO,
                              @"use_price_files": @NO,
                              @"username": @"",
                              @"vendor_account_reference": @"",
                              @"vendor_department_id": @"",
                              @"vendor_email": @"",
                              @"vendor_id": @"",
                              @"vendor_name": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies_vendors/:companies_vendor_id"]
                                                       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}}/companies_vendors/:companies_vendor_id" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies_vendors/:companies_vendor_id",
  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([
    'company_id' => '',
    'delivery_price' => '',
    'free_delivery_price' => '',
    'is_active' => null,
    'password' => '',
    'receive_automatic_price_files' => null,
    'receive_invoice_mails' => null,
    'reviewed' => null,
    'use_price_files' => null,
    'username' => '',
    'vendor_account_reference' => '',
    'vendor_department_id' => '',
    'vendor_email' => '',
    'vendor_id' => '',
    'vendor_name' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/companies_vendors/:companies_vendor_id', [
  'body' => '{
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies_vendors/:companies_vendor_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'company_id' => '',
  'delivery_price' => '',
  'free_delivery_price' => '',
  'is_active' => null,
  'password' => '',
  'receive_automatic_price_files' => null,
  'receive_invoice_mails' => null,
  'reviewed' => null,
  'use_price_files' => null,
  'username' => '',
  'vendor_account_reference' => '',
  'vendor_department_id' => '',
  'vendor_email' => '',
  'vendor_id' => '',
  'vendor_name' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'company_id' => '',
  'delivery_price' => '',
  'free_delivery_price' => '',
  'is_active' => null,
  'password' => '',
  'receive_automatic_price_files' => null,
  'receive_invoice_mails' => null,
  'reviewed' => null,
  'use_price_files' => null,
  'username' => '',
  'vendor_account_reference' => '',
  'vendor_department_id' => '',
  'vendor_email' => '',
  'vendor_id' => '',
  'vendor_name' => ''
]));
$request->setRequestUrl('{{baseUrl}}/companies_vendors/:companies_vendor_id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies_vendors/:companies_vendor_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies_vendors/:companies_vendor_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/companies_vendors/:companies_vendor_id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/companies_vendors/:companies_vendor_id"

payload = {
    "company_id": "",
    "delivery_price": "",
    "free_delivery_price": "",
    "is_active": False,
    "password": "",
    "receive_automatic_price_files": False,
    "receive_invoice_mails": False,
    "reviewed": False,
    "use_price_files": False,
    "username": "",
    "vendor_account_reference": "",
    "vendor_department_id": "",
    "vendor_email": "",
    "vendor_id": "",
    "vendor_name": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/companies_vendors/:companies_vendor_id"

payload <- "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_name\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/companies_vendors/:companies_vendor_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_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/companies_vendors/:companies_vendor_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"company_id\": \"\",\n  \"delivery_price\": \"\",\n  \"free_delivery_price\": \"\",\n  \"is_active\": false,\n  \"password\": \"\",\n  \"receive_automatic_price_files\": false,\n  \"receive_invoice_mails\": false,\n  \"reviewed\": false,\n  \"use_price_files\": false,\n  \"username\": \"\",\n  \"vendor_account_reference\": \"\",\n  \"vendor_department_id\": \"\",\n  \"vendor_email\": \"\",\n  \"vendor_id\": \"\",\n  \"vendor_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}}/companies_vendors/:companies_vendor_id";

    let payload = json!({
        "company_id": "",
        "delivery_price": "",
        "free_delivery_price": "",
        "is_active": false,
        "password": "",
        "receive_automatic_price_files": false,
        "receive_invoice_mails": false,
        "reviewed": false,
        "use_price_files": false,
        "username": "",
        "vendor_account_reference": "",
        "vendor_department_id": "",
        "vendor_email": "",
        "vendor_id": "",
        "vendor_name": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies_vendors/:companies_vendor_id \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
}'
echo '{
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
}' |  \
  http PUT {{baseUrl}}/companies_vendors/:companies_vendor_id \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "company_id": "",\n  "delivery_price": "",\n  "free_delivery_price": "",\n  "is_active": false,\n  "password": "",\n  "receive_automatic_price_files": false,\n  "receive_invoice_mails": false,\n  "reviewed": false,\n  "use_price_files": false,\n  "username": "",\n  "vendor_account_reference": "",\n  "vendor_department_id": "",\n  "vendor_email": "",\n  "vendor_id": "",\n  "vendor_name": ""\n}' \
  --output-document \
  - {{baseUrl}}/companies_vendors/:companies_vendor_id
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "company_id": "",
  "delivery_price": "",
  "free_delivery_price": "",
  "is_active": false,
  "password": "",
  "receive_automatic_price_files": false,
  "receive_invoice_mails": false,
  "reviewed": false,
  "use_price_files": false,
  "username": "",
  "vendor_account_reference": "",
  "vendor_department_id": "",
  "vendor_email": "",
  "vendor_id": "",
  "vendor_name": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies_vendors/:companies_vendor_id")! 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 Get a companies vendor
{{baseUrl}}/companies_vendors/:companies_vendor_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

companies_vendor_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies_vendors/:companies_vendor_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/companies_vendors/:companies_vendor_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies_vendors/:companies_vendor_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies_vendors/:companies_vendor_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies_vendors/:companies_vendor_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/companies_vendors/:companies_vendor_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/companies_vendors/:companies_vendor_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/companies_vendors/:companies_vendor_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies_vendors/:companies_vendor_id"))
    .header("x-auth-token", "{{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}}/companies_vendors/:companies_vendor_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/companies_vendors/:companies_vendor_id")
  .header("x-auth-token", "{{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}}/companies_vendors/:companies_vendor_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies_vendors/:companies_vendor_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies_vendors/:companies_vendor_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies_vendors/:companies_vendor_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/companies_vendors/:companies_vendor_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies_vendors/:companies_vendor_id',
  headers: {
    'x-auth-token': '{{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}}/companies_vendors/:companies_vendor_id',
  headers: {'x-auth-token': '{{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}}/companies_vendors/:companies_vendor_id');

req.headers({
  'x-auth-token': '{{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}}/companies_vendors/:companies_vendor_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/companies_vendors/:companies_vendor_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies_vendors/:companies_vendor_id"]
                                                       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}}/companies_vendors/:companies_vendor_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies_vendors/:companies_vendor_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies_vendors/:companies_vendor_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies_vendors/:companies_vendor_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies_vendors/:companies_vendor_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies_vendors/:companies_vendor_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies_vendors/:companies_vendor_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies_vendors/:companies_vendor_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/companies_vendors/:companies_vendor_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/companies_vendors/:companies_vendor_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/companies_vendors/:companies_vendor_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/companies_vendors/:companies_vendor_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies_vendors/:companies_vendor_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies_vendors/:companies_vendor_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/companies_vendors/:companies_vendor_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies_vendors/:companies_vendor_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies_vendors/:companies_vendor_id")! 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 a list of companies vendors
{{baseUrl}}/companies_vendors
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies_vendors");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/companies_vendors" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies_vendors"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies_vendors"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies_vendors");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/companies_vendors"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/companies_vendors HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/companies_vendors")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies_vendors"))
    .header("x-auth-token", "{{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}}/companies_vendors")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/companies_vendors")
  .header("x-auth-token", "{{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}}/companies_vendors');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies_vendors',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies_vendors';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies_vendors',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/companies_vendors")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies_vendors',
  headers: {
    'x-auth-token': '{{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}}/companies_vendors',
  headers: {'x-auth-token': '{{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}}/companies_vendors');

req.headers({
  'x-auth-token': '{{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}}/companies_vendors',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/companies_vendors';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies_vendors"]
                                                       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}}/companies_vendors" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies_vendors",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies_vendors', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies_vendors');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies_vendors');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies_vendors' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies_vendors' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies_vendors", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/companies_vendors"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/companies_vendors"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/companies_vendors")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/companies_vendors') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies_vendors";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies_vendors \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/companies_vendors \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies_vendors
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies_vendors")! 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 companies vendor expense statistics
{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

companies_vendor_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/companies_vendors/:companies_vendor_id/expense_statistics"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/companies_vendors/:companies_vendor_id/expense_statistics HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics"))
    .header("x-auth-token", "{{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}}/companies_vendors/:companies_vendor_id/expense_statistics")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics")
  .header("x-auth-token", "{{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}}/companies_vendors/:companies_vendor_id/expense_statistics');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/companies_vendors/:companies_vendor_id/expense_statistics',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/companies_vendors/:companies_vendor_id/expense_statistics',
  headers: {
    'x-auth-token': '{{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}}/companies_vendors/:companies_vendor_id/expense_statistics',
  headers: {'x-auth-token': '{{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}}/companies_vendors/:companies_vendor_id/expense_statistics');

req.headers({
  'x-auth-token': '{{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}}/companies_vendors/:companies_vendor_id/expense_statistics',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics"]
                                                       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}}/companies_vendors/:companies_vendor_id/expense_statistics" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/companies_vendors/:companies_vendor_id/expense_statistics", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/companies_vendors/:companies_vendor_id/expense_statistics') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/companies_vendors/:companies_vendor_id/expense_statistics \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/companies_vendors/:companies_vendor_id/expense_statistics")! 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 a list of company settings
{{baseUrl}}/company_settings
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/company_settings");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/company_settings" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/company_settings"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/company_settings"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/company_settings");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/company_settings"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/company_settings HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/company_settings")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/company_settings"))
    .header("x-auth-token", "{{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}}/company_settings")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/company_settings")
  .header("x-auth-token", "{{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}}/company_settings');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/company_settings',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/company_settings';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/company_settings',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/company_settings")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/company_settings',
  headers: {
    'x-auth-token': '{{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}}/company_settings',
  headers: {'x-auth-token': '{{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}}/company_settings');

req.headers({
  'x-auth-token': '{{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}}/company_settings',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/company_settings';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/company_settings"]
                                                       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}}/company_settings" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/company_settings",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/company_settings', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/company_settings');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/company_settings');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/company_settings' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/company_settings' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/company_settings", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/company_settings"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/company_settings"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/company_settings")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/company_settings') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/company_settings";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/company_settings \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/company_settings \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/company_settings
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/company_settings")! 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 Details of 1 contact custom field attribute
{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

contact_custom_field_attribute_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/contact_custom_field_attributes/:contact_custom_field_attribute_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/contact_custom_field_attributes/:contact_custom_field_attribute_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id"))
    .header("x-auth-token", "{{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}}/contact_custom_field_attributes/:contact_custom_field_attribute_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id")
  .header("x-auth-token", "{{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}}/contact_custom_field_attributes/:contact_custom_field_attribute_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/contact_custom_field_attributes/:contact_custom_field_attribute_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/contact_custom_field_attributes/:contact_custom_field_attribute_id',
  headers: {
    'x-auth-token': '{{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}}/contact_custom_field_attributes/:contact_custom_field_attribute_id',
  headers: {'x-auth-token': '{{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}}/contact_custom_field_attributes/:contact_custom_field_attribute_id');

req.headers({
  'x-auth-token': '{{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}}/contact_custom_field_attributes/:contact_custom_field_attribute_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id"]
                                                       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}}/contact_custom_field_attributes/:contact_custom_field_attribute_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/contact_custom_field_attributes/:contact_custom_field_attribute_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/contact_custom_field_attributes/:contact_custom_field_attribute_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contact_custom_field_attributes/:contact_custom_field_attribute_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contact_custom_field_attributes/:contact_custom_field_attribute_id")! 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 a list of contact custom field attributes
{{baseUrl}}/contact_custom_field_attributes
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contact_custom_field_attributes");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/contact_custom_field_attributes" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/contact_custom_field_attributes"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/contact_custom_field_attributes"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/contact_custom_field_attributes");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contact_custom_field_attributes"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/contact_custom_field_attributes HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/contact_custom_field_attributes")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contact_custom_field_attributes"))
    .header("x-auth-token", "{{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}}/contact_custom_field_attributes")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/contact_custom_field_attributes")
  .header("x-auth-token", "{{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}}/contact_custom_field_attributes');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/contact_custom_field_attributes',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contact_custom_field_attributes';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/contact_custom_field_attributes',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/contact_custom_field_attributes")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/contact_custom_field_attributes',
  headers: {
    'x-auth-token': '{{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}}/contact_custom_field_attributes',
  headers: {'x-auth-token': '{{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}}/contact_custom_field_attributes');

req.headers({
  'x-auth-token': '{{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}}/contact_custom_field_attributes',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contact_custom_field_attributes';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contact_custom_field_attributes"]
                                                       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}}/contact_custom_field_attributes" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contact_custom_field_attributes",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/contact_custom_field_attributes', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contact_custom_field_attributes');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/contact_custom_field_attributes');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contact_custom_field_attributes' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contact_custom_field_attributes' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/contact_custom_field_attributes", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contact_custom_field_attributes"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contact_custom_field_attributes"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contact_custom_field_attributes")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/contact_custom_field_attributes') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/contact_custom_field_attributes";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contact_custom_field_attributes \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/contact_custom_field_attributes \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/contact_custom_field_attributes
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contact_custom_field_attributes")! 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 a list of contact custom field values
{{baseUrl}}/contacts/:contact_id/contact_custom_field_values
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

contact_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contacts/:contact_id/contact_custom_field_values");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/contacts/:contact_id/contact_custom_field_values" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/contacts/:contact_id/contact_custom_field_values"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/contacts/:contact_id/contact_custom_field_values"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/contacts/:contact_id/contact_custom_field_values");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contacts/:contact_id/contact_custom_field_values"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/contacts/:contact_id/contact_custom_field_values HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/contacts/:contact_id/contact_custom_field_values")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contacts/:contact_id/contact_custom_field_values"))
    .header("x-auth-token", "{{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}}/contacts/:contact_id/contact_custom_field_values")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/contacts/:contact_id/contact_custom_field_values")
  .header("x-auth-token", "{{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}}/contacts/:contact_id/contact_custom_field_values');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/contacts/:contact_id/contact_custom_field_values',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contacts/:contact_id/contact_custom_field_values';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/contacts/:contact_id/contact_custom_field_values',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/contacts/:contact_id/contact_custom_field_values")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/contacts/:contact_id/contact_custom_field_values',
  headers: {
    'x-auth-token': '{{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}}/contacts/:contact_id/contact_custom_field_values',
  headers: {'x-auth-token': '{{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}}/contacts/:contact_id/contact_custom_field_values');

req.headers({
  'x-auth-token': '{{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}}/contacts/:contact_id/contact_custom_field_values',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contacts/:contact_id/contact_custom_field_values';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contacts/:contact_id/contact_custom_field_values"]
                                                       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}}/contacts/:contact_id/contact_custom_field_values" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contacts/:contact_id/contact_custom_field_values",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/contacts/:contact_id/contact_custom_field_values', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contacts/:contact_id/contact_custom_field_values');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/contacts/:contact_id/contact_custom_field_values');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contacts/:contact_id/contact_custom_field_values' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contacts/:contact_id/contact_custom_field_values' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/contacts/:contact_id/contact_custom_field_values", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contacts/:contact_id/contact_custom_field_values"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contacts/:contact_id/contact_custom_field_values"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contacts/:contact_id/contact_custom_field_values")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/contacts/:contact_id/contact_custom_field_values') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/contacts/:contact_id/contact_custom_field_values";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contacts/:contact_id/contact_custom_field_values \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/contacts/:contact_id/contact_custom_field_values \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/contacts/:contact_id/contact_custom_field_values
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contacts/:contact_id/contact_custom_field_values")! 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 a new contact person to a contact
{{baseUrl}}/contacts/:contact_id/contact_persons
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

contact_id
BODY json

{
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contacts/:contact_id/contact_persons");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
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  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/contacts/:contact_id/contact_persons" {:headers {:x-auth-token "{{apiKey}}"}
                                                                                 :content-type :json
                                                                                 :form-params {:email ""
                                                                                               :name ""
                                                                                               :phone ""
                                                                                               :title ""}})
require "http/client"

url = "{{baseUrl}}/contacts/:contact_id/contact_persons"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\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}}/contacts/:contact_id/contact_persons"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\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}}/contacts/:contact_id/contact_persons");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contacts/:contact_id/contact_persons"

	payload := strings.NewReader("{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/contacts/:contact_id/contact_persons HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 61

{
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/contacts/:contact_id/contact_persons")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contacts/:contact_id/contact_persons"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\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  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/contacts/:contact_id/contact_persons")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/contacts/:contact_id/contact_persons")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  email: '',
  name: '',
  phone: '',
  title: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/contacts/:contact_id/contact_persons');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/contacts/:contact_id/contact_persons',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {email: '', name: '', phone: '', title: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contacts/:contact_id/contact_persons';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"email":"","name":"","phone":"","title":""}'
};

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}}/contacts/:contact_id/contact_persons',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "email": "",\n  "name": "",\n  "phone": "",\n  "title": ""\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  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/contacts/:contact_id/contact_persons")
  .post(body)
  .addHeader("x-auth-token", "{{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/contacts/:contact_id/contact_persons',
  headers: {
    'x-auth-token': '{{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({email: '', name: '', phone: '', title: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/contacts/:contact_id/contact_persons',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {email: '', name: '', phone: '', title: ''},
  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}}/contacts/:contact_id/contact_persons');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  email: '',
  name: '',
  phone: '',
  title: ''
});

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}}/contacts/:contact_id/contact_persons',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {email: '', name: '', phone: '', title: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contacts/:contact_id/contact_persons';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"email":"","name":"","phone":"","title":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"email": @"",
                              @"name": @"",
                              @"phone": @"",
                              @"title": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contacts/:contact_id/contact_persons"]
                                                       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}}/contacts/:contact_id/contact_persons" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contacts/:contact_id/contact_persons",
  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' => '',
    'name' => '',
    'phone' => '',
    'title' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/contacts/:contact_id/contact_persons', [
  'body' => '{
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contacts/:contact_id/contact_persons');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'email' => '',
  'name' => '',
  'phone' => '',
  'title' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'email' => '',
  'name' => '',
  'phone' => '',
  'title' => ''
]));
$request->setRequestUrl('{{baseUrl}}/contacts/:contact_id/contact_persons');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contacts/:contact_id/contact_persons' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contacts/:contact_id/contact_persons' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/contacts/:contact_id/contact_persons", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contacts/:contact_id/contact_persons"

payload = {
    "email": "",
    "name": "",
    "phone": "",
    "title": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contacts/:contact_id/contact_persons"

payload <- "{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contacts/:contact_id/contact_persons")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\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/contacts/:contact_id/contact_persons') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/contacts/:contact_id/contact_persons";

    let payload = json!({
        "email": "",
        "name": "",
        "phone": "",
        "title": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contacts/:contact_id/contact_persons \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
}'
echo '{
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
}' |  \
  http POST {{baseUrl}}/contacts/:contact_id/contact_persons \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "email": "",\n  "name": "",\n  "phone": "",\n  "title": ""\n}' \
  --output-document \
  - {{baseUrl}}/contacts/:contact_id/contact_persons
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contacts/:contact_id/contact_persons")! 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 Delete a contact person
{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

contact_id
contact_person_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/contacts/:contact_id/contact_persons/:contact_person_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/contacts/:contact_id/contact_persons/:contact_person_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"))
    .header("x-auth-token", "{{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}}/contacts/:contact_id/contact_persons/:contact_person_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")
  .header("x-auth-token", "{{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}}/contacts/:contact_id/contact_persons/:contact_person_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/contacts/:contact_id/contact_persons/:contact_person_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/contacts/:contact_id/contact_persons/:contact_person_id',
  headers: {
    'x-auth-token': '{{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}}/contacts/:contact_id/contact_persons/:contact_person_id',
  headers: {'x-auth-token': '{{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}}/contacts/:contact_id/contact_persons/:contact_person_id');

req.headers({
  'x-auth-token': '{{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}}/contacts/:contact_id/contact_persons/:contact_person_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"]
                                                       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}}/contacts/:contact_id/contact_persons/:contact_person_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/contacts/:contact_id/contact_persons/:contact_person_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/contacts/:contact_id/contact_persons/:contact_person_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contacts/:contact_id/contact_persons/:contact_person_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")! 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()
PUT Edit a contact person
{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

contact_id
contact_person_id
BODY json

{
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
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  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id" {:headers {:x-auth-token "{{apiKey}}"}
                                                                                                   :content-type :json
                                                                                                   :form-params {:email ""
                                                                                                                 :name ""
                                                                                                                 :phone ""
                                                                                                                 :title ""}})
require "http/client"

url = "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\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}}/contacts/:contact_id/contact_persons/:contact_person_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\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}}/contacts/:contact_id/contact_persons/:contact_person_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"

	payload := strings.NewReader("{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("x-auth-token", "{{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/contacts/:contact_id/contact_persons/:contact_person_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 61

{
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\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  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")
  .put(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  email: '',
  name: '',
  phone: '',
  title: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {email: '', name: '', phone: '', title: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id';
const options = {
  method: 'PUT',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"email":"","name":"","phone":"","title":""}'
};

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}}/contacts/:contact_id/contact_persons/:contact_person_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "email": "",\n  "name": "",\n  "phone": "",\n  "title": ""\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  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")
  .put(body)
  .addHeader("x-auth-token", "{{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/contacts/:contact_id/contact_persons/:contact_person_id',
  headers: {
    'x-auth-token': '{{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({email: '', name: '', phone: '', title: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {email: '', name: '', phone: '', title: ''},
  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}}/contacts/:contact_id/contact_persons/:contact_person_id');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  email: '',
  name: '',
  phone: '',
  title: ''
});

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}}/contacts/:contact_id/contact_persons/:contact_person_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {email: '', name: '', phone: '', title: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id';
const options = {
  method: 'PUT',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"email":"","name":"","phone":"","title":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"email": @"",
                              @"name": @"",
                              @"phone": @"",
                              @"title": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"]
                                                       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}}/contacts/:contact_id/contact_persons/:contact_person_id" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id",
  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([
    'email' => '',
    'name' => '',
    'phone' => '',
    'title' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id', [
  'body' => '{
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'email' => '',
  'name' => '',
  'phone' => '',
  'title' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'email' => '',
  'name' => '',
  'phone' => '',
  'title' => ''
]));
$request->setRequestUrl('{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/contacts/:contact_id/contact_persons/:contact_person_id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"

payload = {
    "email": "",
    "name": "",
    "phone": "",
    "title": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"

payload <- "{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\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/contacts/:contact_id/contact_persons/:contact_person_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"email\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"title\": \"\"\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}}/contacts/:contact_id/contact_persons/:contact_person_id";

    let payload = json!({
        "email": "",
        "name": "",
        "phone": "",
        "title": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contacts/:contact_id/contact_persons/:contact_person_id \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
}'
echo '{
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
}' |  \
  http PUT {{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "email": "",\n  "name": "",\n  "phone": "",\n  "title": ""\n}' \
  --output-document \
  - {{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "email": "",
  "name": "",
  "phone": "",
  "title": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")! 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 Get a contact person
{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

contact_id
contact_person_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/contacts/:contact_id/contact_persons/:contact_person_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/contacts/:contact_id/contact_persons/:contact_person_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"))
    .header("x-auth-token", "{{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}}/contacts/:contact_id/contact_persons/:contact_person_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")
  .header("x-auth-token", "{{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}}/contacts/:contact_id/contact_persons/:contact_person_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/contacts/:contact_id/contact_persons/:contact_person_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/contacts/:contact_id/contact_persons/:contact_person_id',
  headers: {
    'x-auth-token': '{{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}}/contacts/:contact_id/contact_persons/:contact_person_id',
  headers: {'x-auth-token': '{{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}}/contacts/:contact_id/contact_persons/:contact_person_id');

req.headers({
  'x-auth-token': '{{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}}/contacts/:contact_id/contact_persons/:contact_person_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"]
                                                       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}}/contacts/:contact_id/contact_persons/:contact_person_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/contacts/:contact_id/contact_persons/:contact_person_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/contacts/:contact_id/contact_persons/:contact_person_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contacts/:contact_id/contact_persons/:contact_person_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contacts/:contact_id/contact_persons/:contact_person_id")! 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 a list of contact people
{{baseUrl}}/contacts/:contact_id/contact_persons
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

contact_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contacts/:contact_id/contact_persons");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/contacts/:contact_id/contact_persons" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/contacts/:contact_id/contact_persons"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/contacts/:contact_id/contact_persons"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/contacts/:contact_id/contact_persons");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contacts/:contact_id/contact_persons"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/contacts/:contact_id/contact_persons HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/contacts/:contact_id/contact_persons")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contacts/:contact_id/contact_persons"))
    .header("x-auth-token", "{{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}}/contacts/:contact_id/contact_persons")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/contacts/:contact_id/contact_persons")
  .header("x-auth-token", "{{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}}/contacts/:contact_id/contact_persons');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/contacts/:contact_id/contact_persons',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contacts/:contact_id/contact_persons';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/contacts/:contact_id/contact_persons',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/contacts/:contact_id/contact_persons")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/contacts/:contact_id/contact_persons',
  headers: {
    'x-auth-token': '{{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}}/contacts/:contact_id/contact_persons',
  headers: {'x-auth-token': '{{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}}/contacts/:contact_id/contact_persons');

req.headers({
  'x-auth-token': '{{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}}/contacts/:contact_id/contact_persons',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contacts/:contact_id/contact_persons';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contacts/:contact_id/contact_persons"]
                                                       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}}/contacts/:contact_id/contact_persons" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contacts/:contact_id/contact_persons",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/contacts/:contact_id/contact_persons', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contacts/:contact_id/contact_persons');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/contacts/:contact_id/contact_persons');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contacts/:contact_id/contact_persons' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contacts/:contact_id/contact_persons' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/contacts/:contact_id/contact_persons", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contacts/:contact_id/contact_persons"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contacts/:contact_id/contact_persons"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contacts/:contact_id/contact_persons")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/contacts/:contact_id/contact_persons') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/contacts/:contact_id/contact_persons";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contacts/:contact_id/contact_persons \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/contacts/:contact_id/contact_persons \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/contacts/:contact_id/contact_persons
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contacts/:contact_id/contact_persons")! 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 a new contact
{{baseUrl}}/contacts
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "address": "",
  "city_id": "",
  "contact_types": {
    "_ids": []
  },
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contacts");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/contacts" {:headers {:x-auth-token "{{apiKey}}"}
                                                     :content-type :json
                                                     :form-params {:address ""
                                                                   :city_id ""
                                                                   :contact_types {:_ids []}
                                                                   :cvr ""
                                                                   :description ""
                                                                   :email ""
                                                                   :erp_id ""
                                                                   :name ""
                                                                   :phone ""
                                                                   :website ""}})
require "http/client"

url = "{{baseUrl}}/contacts"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\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}}/contacts"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\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}}/contacts");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contacts"

	payload := strings.NewReader("{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/contacts HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 188

{
  "address": "",
  "city_id": "",
  "contact_types": {
    "_ids": []
  },
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/contacts")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contacts"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\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  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/contacts")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/contacts")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  address: '',
  city_id: '',
  contact_types: {
    _ids: []
  },
  cvr: '',
  description: '',
  email: '',
  erp_id: '',
  name: '',
  phone: '',
  website: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/contacts');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/contacts',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    address: '',
    city_id: '',
    contact_types: {_ids: []},
    cvr: '',
    description: '',
    email: '',
    erp_id: '',
    name: '',
    phone: '',
    website: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contacts';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"address":"","city_id":"","contact_types":{"_ids":[]},"cvr":"","description":"","email":"","erp_id":"","name":"","phone":"","website":""}'
};

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}}/contacts',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address": "",\n  "city_id": "",\n  "contact_types": {\n    "_ids": []\n  },\n  "cvr": "",\n  "description": "",\n  "email": "",\n  "erp_id": "",\n  "name": "",\n  "phone": "",\n  "website": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/contacts")
  .post(body)
  .addHeader("x-auth-token", "{{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/contacts',
  headers: {
    'x-auth-token': '{{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({
  address: '',
  city_id: '',
  contact_types: {_ids: []},
  cvr: '',
  description: '',
  email: '',
  erp_id: '',
  name: '',
  phone: '',
  website: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/contacts',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    address: '',
    city_id: '',
    contact_types: {_ids: []},
    cvr: '',
    description: '',
    email: '',
    erp_id: '',
    name: '',
    phone: '',
    website: ''
  },
  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}}/contacts');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address: '',
  city_id: '',
  contact_types: {
    _ids: []
  },
  cvr: '',
  description: '',
  email: '',
  erp_id: '',
  name: '',
  phone: '',
  website: ''
});

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}}/contacts',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    address: '',
    city_id: '',
    contact_types: {_ids: []},
    cvr: '',
    description: '',
    email: '',
    erp_id: '',
    name: '',
    phone: '',
    website: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contacts';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"address":"","city_id":"","contact_types":{"_ids":[]},"cvr":"","description":"","email":"","erp_id":"","name":"","phone":"","website":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address": @"",
                              @"city_id": @"",
                              @"contact_types": @{ @"_ids": @[  ] },
                              @"cvr": @"",
                              @"description": @"",
                              @"email": @"",
                              @"erp_id": @"",
                              @"name": @"",
                              @"phone": @"",
                              @"website": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contacts"]
                                                       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}}/contacts" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contacts",
  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([
    'address' => '',
    'city_id' => '',
    'contact_types' => [
        '_ids' => [
                
        ]
    ],
    'cvr' => '',
    'description' => '',
    'email' => '',
    'erp_id' => '',
    'name' => '',
    'phone' => '',
    'website' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/contacts', [
  'body' => '{
  "address": "",
  "city_id": "",
  "contact_types": {
    "_ids": []
  },
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contacts');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address' => '',
  'city_id' => '',
  'contact_types' => [
    '_ids' => [
        
    ]
  ],
  'cvr' => '',
  'description' => '',
  'email' => '',
  'erp_id' => '',
  'name' => '',
  'phone' => '',
  'website' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address' => '',
  'city_id' => '',
  'contact_types' => [
    '_ids' => [
        
    ]
  ],
  'cvr' => '',
  'description' => '',
  'email' => '',
  'erp_id' => '',
  'name' => '',
  'phone' => '',
  'website' => ''
]));
$request->setRequestUrl('{{baseUrl}}/contacts');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contacts' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": "",
  "city_id": "",
  "contact_types": {
    "_ids": []
  },
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contacts' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address": "",
  "city_id": "",
  "contact_types": {
    "_ids": []
  },
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/contacts", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contacts"

payload = {
    "address": "",
    "city_id": "",
    "contact_types": { "_ids": [] },
    "cvr": "",
    "description": "",
    "email": "",
    "erp_id": "",
    "name": "",
    "phone": "",
    "website": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contacts"

payload <- "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contacts")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\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/contacts') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/contacts";

    let payload = json!({
        "address": "",
        "city_id": "",
        "contact_types": json!({"_ids": ()}),
        "cvr": "",
        "description": "",
        "email": "",
        "erp_id": "",
        "name": "",
        "phone": "",
        "website": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contacts \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "address": "",
  "city_id": "",
  "contact_types": {
    "_ids": []
  },
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
}'
echo '{
  "address": "",
  "city_id": "",
  "contact_types": {
    "_ids": []
  },
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
}' |  \
  http POST {{baseUrl}}/contacts \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "address": "",\n  "city_id": "",\n  "contact_types": {\n    "_ids": []\n  },\n  "cvr": "",\n  "description": "",\n  "email": "",\n  "erp_id": "",\n  "name": "",\n  "phone": "",\n  "website": ""\n}' \
  --output-document \
  - {{baseUrl}}/contacts
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "address": "",
  "city_id": "",
  "contact_types": ["_ids": []],
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contacts")! 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 Bulk delete contacts
{{baseUrl}}/contacts/bulkDelete
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contacts/bulkDelete");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/contacts/bulkDelete" {:headers {:x-auth-token "{{apiKey}}"}
                                                                  :content-type :json
                                                                  :form-params {:id []}})
require "http/client"

url = "{{baseUrl}}/contacts/bulkDelete"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": []\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}}/contacts/bulkDelete"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id\": []\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}}/contacts/bulkDelete");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contacts/bulkDelete"

	payload := strings.NewReader("{\n  \"id\": []\n}")

	req, _ := http.NewRequest("DELETE", url, payload)

	req.Header.Add("x-auth-token", "{{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/contacts/bulkDelete HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/contacts/bulkDelete")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contacts/bulkDelete"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"id\": []\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\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/contacts/bulkDelete")
  .delete(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/contacts/bulkDelete")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/contacts/bulkDelete');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/contacts/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contacts/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/contacts/bulkDelete',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/contacts/bulkDelete")
  .delete(body)
  .addHeader("x-auth-token", "{{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/contacts/bulkDelete',
  headers: {
    'x-auth-token': '{{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: []}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/contacts/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {id: []},
  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}}/contacts/bulkDelete');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: []
});

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}}/contacts/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contacts/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contacts/bulkDelete"]
                                                       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}}/contacts/bulkDelete" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": []\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contacts/bulkDelete",
  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([
    'id' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/contacts/bulkDelete', [
  'body' => '{
  "id": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contacts/bulkDelete');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/contacts/bulkDelete');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contacts/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contacts/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": []\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("DELETE", "/baseUrl/contacts/bulkDelete", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contacts/bulkDelete"

payload = { "id": [] }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contacts/bulkDelete"

payload <- "{\n  \"id\": []\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contacts/bulkDelete")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/contacts/bulkDelete') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"id\": []\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}}/contacts/bulkDelete";

    let payload = json!({"id": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contacts/bulkDelete \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http DELETE {{baseUrl}}/contacts/bulkDelete \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/contacts/bulkDelete
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contacts/bulkDelete")! 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 a contact
{{baseUrl}}/contacts/:contact_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

contact_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contacts/:contact_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/contacts/:contact_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/contacts/:contact_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/contacts/:contact_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/contacts/:contact_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contacts/:contact_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/contacts/:contact_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/contacts/:contact_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contacts/:contact_id"))
    .header("x-auth-token", "{{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}}/contacts/:contact_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/contacts/:contact_id")
  .header("x-auth-token", "{{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}}/contacts/:contact_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/contacts/:contact_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contacts/:contact_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/contacts/:contact_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/contacts/:contact_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/contacts/:contact_id',
  headers: {
    'x-auth-token': '{{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}}/contacts/:contact_id',
  headers: {'x-auth-token': '{{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}}/contacts/:contact_id');

req.headers({
  'x-auth-token': '{{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}}/contacts/:contact_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contacts/:contact_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contacts/:contact_id"]
                                                       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}}/contacts/:contact_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contacts/:contact_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/contacts/:contact_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contacts/:contact_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/contacts/:contact_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contacts/:contact_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contacts/:contact_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/contacts/:contact_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contacts/:contact_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contacts/:contact_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contacts/:contact_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/contacts/:contact_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/contacts/:contact_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contacts/:contact_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/contacts/:contact_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/contacts/:contact_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contacts/:contact_id")! 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 Details of 1 contact
{{baseUrl}}/contacts/:contact_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

contact_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contacts/:contact_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/contacts/:contact_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/contacts/:contact_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/contacts/:contact_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/contacts/:contact_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contacts/:contact_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/contacts/:contact_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/contacts/:contact_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contacts/:contact_id"))
    .header("x-auth-token", "{{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}}/contacts/:contact_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/contacts/:contact_id")
  .header("x-auth-token", "{{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}}/contacts/:contact_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/contacts/:contact_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contacts/:contact_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/contacts/:contact_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/contacts/:contact_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/contacts/:contact_id',
  headers: {
    'x-auth-token': '{{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}}/contacts/:contact_id',
  headers: {'x-auth-token': '{{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}}/contacts/:contact_id');

req.headers({
  'x-auth-token': '{{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}}/contacts/:contact_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contacts/:contact_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contacts/:contact_id"]
                                                       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}}/contacts/:contact_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contacts/:contact_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/contacts/:contact_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contacts/:contact_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/contacts/:contact_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contacts/:contact_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contacts/:contact_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/contacts/:contact_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contacts/:contact_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contacts/:contact_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contacts/:contact_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/contacts/:contact_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/contacts/:contact_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contacts/:contact_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/contacts/:contact_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/contacts/:contact_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contacts/:contact_id")! 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 Edit a contact
{{baseUrl}}/contacts/:contact_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

contact_id
BODY json

{
  "address": "",
  "city_id": "",
  "contact_types": {
    "_ids": []
  },
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contacts/:contact_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/contacts/:contact_id" {:headers {:x-auth-token "{{apiKey}}"}
                                                                :content-type :json
                                                                :form-params {:address ""
                                                                              :city_id ""
                                                                              :contact_types {:_ids []}
                                                                              :cvr ""
                                                                              :description ""
                                                                              :email ""
                                                                              :erp_id ""
                                                                              :name ""
                                                                              :phone ""
                                                                              :website ""}})
require "http/client"

url = "{{baseUrl}}/contacts/:contact_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\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}}/contacts/:contact_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\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}}/contacts/:contact_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contacts/:contact_id"

	payload := strings.NewReader("{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("x-auth-token", "{{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/contacts/:contact_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 188

{
  "address": "",
  "city_id": "",
  "contact_types": {
    "_ids": []
  },
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/contacts/:contact_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contacts/:contact_id"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\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  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/contacts/:contact_id")
  .put(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/contacts/:contact_id")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  address: '',
  city_id: '',
  contact_types: {
    _ids: []
  },
  cvr: '',
  description: '',
  email: '',
  erp_id: '',
  name: '',
  phone: '',
  website: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/contacts/:contact_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/contacts/:contact_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    address: '',
    city_id: '',
    contact_types: {_ids: []},
    cvr: '',
    description: '',
    email: '',
    erp_id: '',
    name: '',
    phone: '',
    website: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contacts/:contact_id';
const options = {
  method: 'PUT',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"address":"","city_id":"","contact_types":{"_ids":[]},"cvr":"","description":"","email":"","erp_id":"","name":"","phone":"","website":""}'
};

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}}/contacts/:contact_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address": "",\n  "city_id": "",\n  "contact_types": {\n    "_ids": []\n  },\n  "cvr": "",\n  "description": "",\n  "email": "",\n  "erp_id": "",\n  "name": "",\n  "phone": "",\n  "website": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/contacts/:contact_id")
  .put(body)
  .addHeader("x-auth-token", "{{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/contacts/:contact_id',
  headers: {
    'x-auth-token': '{{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({
  address: '',
  city_id: '',
  contact_types: {_ids: []},
  cvr: '',
  description: '',
  email: '',
  erp_id: '',
  name: '',
  phone: '',
  website: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/contacts/:contact_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    address: '',
    city_id: '',
    contact_types: {_ids: []},
    cvr: '',
    description: '',
    email: '',
    erp_id: '',
    name: '',
    phone: '',
    website: ''
  },
  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}}/contacts/:contact_id');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address: '',
  city_id: '',
  contact_types: {
    _ids: []
  },
  cvr: '',
  description: '',
  email: '',
  erp_id: '',
  name: '',
  phone: '',
  website: ''
});

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}}/contacts/:contact_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    address: '',
    city_id: '',
    contact_types: {_ids: []},
    cvr: '',
    description: '',
    email: '',
    erp_id: '',
    name: '',
    phone: '',
    website: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contacts/:contact_id';
const options = {
  method: 'PUT',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"address":"","city_id":"","contact_types":{"_ids":[]},"cvr":"","description":"","email":"","erp_id":"","name":"","phone":"","website":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address": @"",
                              @"city_id": @"",
                              @"contact_types": @{ @"_ids": @[  ] },
                              @"cvr": @"",
                              @"description": @"",
                              @"email": @"",
                              @"erp_id": @"",
                              @"name": @"",
                              @"phone": @"",
                              @"website": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contacts/:contact_id"]
                                                       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}}/contacts/:contact_id" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contacts/:contact_id",
  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([
    'address' => '',
    'city_id' => '',
    'contact_types' => [
        '_ids' => [
                
        ]
    ],
    'cvr' => '',
    'description' => '',
    'email' => '',
    'erp_id' => '',
    'name' => '',
    'phone' => '',
    'website' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/contacts/:contact_id', [
  'body' => '{
  "address": "",
  "city_id": "",
  "contact_types": {
    "_ids": []
  },
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contacts/:contact_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address' => '',
  'city_id' => '',
  'contact_types' => [
    '_ids' => [
        
    ]
  ],
  'cvr' => '',
  'description' => '',
  'email' => '',
  'erp_id' => '',
  'name' => '',
  'phone' => '',
  'website' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address' => '',
  'city_id' => '',
  'contact_types' => [
    '_ids' => [
        
    ]
  ],
  'cvr' => '',
  'description' => '',
  'email' => '',
  'erp_id' => '',
  'name' => '',
  'phone' => '',
  'website' => ''
]));
$request->setRequestUrl('{{baseUrl}}/contacts/:contact_id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contacts/:contact_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "address": "",
  "city_id": "",
  "contact_types": {
    "_ids": []
  },
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contacts/:contact_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "address": "",
  "city_id": "",
  "contact_types": {
    "_ids": []
  },
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/contacts/:contact_id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contacts/:contact_id"

payload = {
    "address": "",
    "city_id": "",
    "contact_types": { "_ids": [] },
    "cvr": "",
    "description": "",
    "email": "",
    "erp_id": "",
    "name": "",
    "phone": "",
    "website": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contacts/:contact_id"

payload <- "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contacts/:contact_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\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/contacts/:contact_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"address\": \"\",\n  \"city_id\": \"\",\n  \"contact_types\": {\n    \"_ids\": []\n  },\n  \"cvr\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"phone\": \"\",\n  \"website\": \"\"\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}}/contacts/:contact_id";

    let payload = json!({
        "address": "",
        "city_id": "",
        "contact_types": json!({"_ids": ()}),
        "cvr": "",
        "description": "",
        "email": "",
        "erp_id": "",
        "name": "",
        "phone": "",
        "website": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contacts/:contact_id \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "address": "",
  "city_id": "",
  "contact_types": {
    "_ids": []
  },
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
}'
echo '{
  "address": "",
  "city_id": "",
  "contact_types": {
    "_ids": []
  },
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
}' |  \
  http PUT {{baseUrl}}/contacts/:contact_id \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "address": "",\n  "city_id": "",\n  "contact_types": {\n    "_ids": []\n  },\n  "cvr": "",\n  "description": "",\n  "email": "",\n  "erp_id": "",\n  "name": "",\n  "phone": "",\n  "website": ""\n}' \
  --output-document \
  - {{baseUrl}}/contacts/:contact_id
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "address": "",
  "city_id": "",
  "contact_types": ["_ids": []],
  "cvr": "",
  "description": "",
  "email": "",
  "erp_id": "",
  "name": "",
  "phone": "",
  "website": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contacts/:contact_id")! 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 Get a list of contacts
{{baseUrl}}/contacts
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contacts");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/contacts" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/contacts"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/contacts"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/contacts");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contacts"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/contacts HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/contacts")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contacts"))
    .header("x-auth-token", "{{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}}/contacts")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/contacts")
  .header("x-auth-token", "{{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}}/contacts');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/contacts',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contacts';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/contacts',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/contacts")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/contacts',
  headers: {
    'x-auth-token': '{{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}}/contacts',
  headers: {'x-auth-token': '{{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}}/contacts');

req.headers({
  'x-auth-token': '{{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}}/contacts',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contacts';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contacts"]
                                                       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}}/contacts" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contacts",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/contacts', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contacts');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/contacts');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contacts' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contacts' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/contacts", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contacts"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contacts"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contacts")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/contacts') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/contacts";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contacts \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/contacts \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/contacts
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contacts")! 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 details about one contact type
{{baseUrl}}/contact_types/:contact_type_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

contact_type_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contact_types/:contact_type_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/contact_types/:contact_type_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/contact_types/:contact_type_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/contact_types/:contact_type_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/contact_types/:contact_type_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contact_types/:contact_type_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/contact_types/:contact_type_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/contact_types/:contact_type_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contact_types/:contact_type_id"))
    .header("x-auth-token", "{{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}}/contact_types/:contact_type_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/contact_types/:contact_type_id")
  .header("x-auth-token", "{{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}}/contact_types/:contact_type_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/contact_types/:contact_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contact_types/:contact_type_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/contact_types/:contact_type_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/contact_types/:contact_type_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/contact_types/:contact_type_id',
  headers: {
    'x-auth-token': '{{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}}/contact_types/:contact_type_id',
  headers: {'x-auth-token': '{{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}}/contact_types/:contact_type_id');

req.headers({
  'x-auth-token': '{{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}}/contact_types/:contact_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contact_types/:contact_type_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contact_types/:contact_type_id"]
                                                       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}}/contact_types/:contact_type_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contact_types/:contact_type_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/contact_types/:contact_type_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contact_types/:contact_type_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/contact_types/:contact_type_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contact_types/:contact_type_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contact_types/:contact_type_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/contact_types/:contact_type_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contact_types/:contact_type_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contact_types/:contact_type_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contact_types/:contact_type_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/contact_types/:contact_type_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/contact_types/:contact_type_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contact_types/:contact_type_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/contact_types/:contact_type_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/contact_types/:contact_type_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contact_types/:contact_type_id")! 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 list of contact types supported in Apacta
{{baseUrl}}/contact_types
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/contact_types");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/contact_types" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/contact_types"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/contact_types"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/contact_types");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/contact_types"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/contact_types HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/contact_types")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/contact_types"))
    .header("x-auth-token", "{{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}}/contact_types")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/contact_types")
  .header("x-auth-token", "{{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}}/contact_types');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/contact_types',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/contact_types';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/contact_types',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/contact_types")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/contact_types',
  headers: {
    'x-auth-token': '{{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}}/contact_types',
  headers: {'x-auth-token': '{{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}}/contact_types');

req.headers({
  'x-auth-token': '{{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}}/contact_types',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/contact_types';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/contact_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}}/contact_types" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/contact_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 => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/contact_types', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/contact_types');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/contact_types');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/contact_types' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/contact_types' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/contact_types", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/contact_types"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/contact_types"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/contact_types")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/contact_types') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/contact_types";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/contact_types \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/contact_types \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/contact_types
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/contact_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()
GET Get details about one country
{{baseUrl}}/countries/:country_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

country_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/countries/:country_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/countries/:country_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/countries/:country_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/countries/:country_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/countries/:country_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/countries/:country_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/countries/:country_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/countries/:country_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/countries/:country_id"))
    .header("x-auth-token", "{{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}}/countries/:country_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/countries/:country_id")
  .header("x-auth-token", "{{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}}/countries/:country_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/countries/:country_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/countries/:country_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/countries/:country_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/countries/:country_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/countries/:country_id',
  headers: {
    'x-auth-token': '{{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}}/countries/:country_id',
  headers: {'x-auth-token': '{{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}}/countries/:country_id');

req.headers({
  'x-auth-token': '{{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}}/countries/:country_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/countries/:country_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/countries/:country_id"]
                                                       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}}/countries/:country_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/countries/:country_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/countries/:country_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/countries/:country_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/countries/:country_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/countries/:country_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/countries/:country_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/countries/:country_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/countries/:country_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/countries/:country_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/countries/:country_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/countries/:country_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/countries/:country_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/countries/:country_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/countries/:country_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/countries/:country_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/countries/:country_id")! 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 list of countries supported in Apacta
{{baseUrl}}/countries
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/countries");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/countries" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/countries"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/countries"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/countries");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/countries"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/countries HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/countries")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/countries"))
    .header("x-auth-token", "{{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}}/countries")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/countries")
  .header("x-auth-token", "{{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}}/countries');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/countries',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/countries';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/countries',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/countries")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/countries',
  headers: {
    'x-auth-token': '{{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}}/countries',
  headers: {'x-auth-token': '{{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}}/countries');

req.headers({
  'x-auth-token': '{{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}}/countries',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/countries';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/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}}/countries" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/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 => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/countries', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/countries');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/countries');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/countries' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/countries' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/countries", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/countries"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/countries"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/countries")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/countries') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/countries";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/countries \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/countries \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/countries
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/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()
GET Get details about one currency
{{baseUrl}}/currencies/:currency_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

currency_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/currencies/:currency_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/currencies/:currency_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/currencies/:currency_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/currencies/:currency_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/currencies/:currency_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/currencies/:currency_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/currencies/:currency_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/currencies/:currency_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/currencies/:currency_id"))
    .header("x-auth-token", "{{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}}/currencies/:currency_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/currencies/:currency_id")
  .header("x-auth-token", "{{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}}/currencies/:currency_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/currencies/:currency_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/currencies/:currency_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/currencies/:currency_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/currencies/:currency_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/currencies/:currency_id',
  headers: {
    'x-auth-token': '{{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}}/currencies/:currency_id',
  headers: {'x-auth-token': '{{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}}/currencies/:currency_id');

req.headers({
  'x-auth-token': '{{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}}/currencies/:currency_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/currencies/:currency_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/currencies/:currency_id"]
                                                       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}}/currencies/:currency_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/currencies/:currency_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/currencies/:currency_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/currencies/:currency_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/currencies/:currency_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/currencies/:currency_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/currencies/:currency_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/currencies/:currency_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/currencies/:currency_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/currencies/:currency_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/currencies/:currency_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/currencies/:currency_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/currencies/:currency_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/currencies/:currency_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/currencies/:currency_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/currencies/:currency_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/currencies/:currency_id")! 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 list of currencies supported in Apacta
{{baseUrl}}/currencies
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/currencies");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/currencies" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/currencies"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/currencies"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/currencies");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/currencies"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/currencies HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/currencies")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/currencies"))
    .header("x-auth-token", "{{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}}/currencies")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/currencies")
  .header("x-auth-token", "{{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}}/currencies');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/currencies',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/currencies';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/currencies',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/currencies")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/currencies',
  headers: {
    'x-auth-token': '{{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}}/currencies',
  headers: {'x-auth-token': '{{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}}/currencies');

req.headers({
  'x-auth-token': '{{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}}/currencies',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/currencies';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/currencies"]
                                                       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}}/currencies" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/currencies",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/currencies', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/currencies');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/currencies');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/currencies' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/currencies' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/currencies", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/currencies"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/currencies"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/currencies")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/currencies') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/currencies";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/currencies \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/currencies \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/currencies
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/currencies")! 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 default project statuses to company
{{baseUrl}}/project_statuses/add_default
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/project_statuses/add_default");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/project_statuses/add_default")
require "http/client"

url = "{{baseUrl}}/project_statuses/add_default"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/project_statuses/add_default"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/project_statuses/add_default");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/project_statuses/add_default"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/project_statuses/add_default HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/project_statuses/add_default")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/project_statuses/add_default"))
    .method("POST", 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}}/project_statuses/add_default")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/project_statuses/add_default")
  .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('POST', '{{baseUrl}}/project_statuses/add_default');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/project_statuses/add_default'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/project_statuses/add_default';
const options = {method: 'POST'};

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}}/project_statuses/add_default',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/project_statuses/add_default")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/project_statuses/add_default',
  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: 'POST',
  url: '{{baseUrl}}/project_statuses/add_default'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/project_statuses/add_default');

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}}/project_statuses/add_default'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/project_statuses/add_default';
const options = {method: 'POST'};

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}}/project_statuses/add_default"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

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}}/project_statuses/add_default" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/project_statuses/add_default",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/project_statuses/add_default');

echo $response->getBody();
setUrl('{{baseUrl}}/project_statuses/add_default');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/project_statuses/add_default');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/project_statuses/add_default' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/project_statuses/add_default' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/project_statuses/add_default")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/project_statuses/add_default"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/project_statuses/add_default"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/project_statuses/add_default")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/project_statuses/add_default') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/project_statuses/add_default";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/project_statuses/add_default
http POST {{baseUrl}}/project_statuses/add_default
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/project_statuses/add_default
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/project_statuses/add_default")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

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 Bulk delete driving types
{{baseUrl}}/driving_types/bulkDelete
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/driving_types/bulkDelete");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/driving_types/bulkDelete" {:headers {:x-auth-token "{{apiKey}}"}
                                                                       :content-type :json
                                                                       :form-params {:id []}})
require "http/client"

url = "{{baseUrl}}/driving_types/bulkDelete"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": []\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}}/driving_types/bulkDelete"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id\": []\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}}/driving_types/bulkDelete");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/driving_types/bulkDelete"

	payload := strings.NewReader("{\n  \"id\": []\n}")

	req, _ := http.NewRequest("DELETE", url, payload)

	req.Header.Add("x-auth-token", "{{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/driving_types/bulkDelete HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/driving_types/bulkDelete")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/driving_types/bulkDelete"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"id\": []\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\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/driving_types/bulkDelete")
  .delete(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/driving_types/bulkDelete")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/driving_types/bulkDelete');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/driving_types/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/driving_types/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/driving_types/bulkDelete',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/driving_types/bulkDelete")
  .delete(body)
  .addHeader("x-auth-token", "{{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/driving_types/bulkDelete',
  headers: {
    'x-auth-token': '{{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: []}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/driving_types/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {id: []},
  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}}/driving_types/bulkDelete');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: []
});

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}}/driving_types/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/driving_types/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/driving_types/bulkDelete"]
                                                       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}}/driving_types/bulkDelete" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": []\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/driving_types/bulkDelete",
  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([
    'id' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/driving_types/bulkDelete', [
  'body' => '{
  "id": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/driving_types/bulkDelete');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/driving_types/bulkDelete');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/driving_types/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/driving_types/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": []\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("DELETE", "/baseUrl/driving_types/bulkDelete", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/driving_types/bulkDelete"

payload = { "id": [] }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/driving_types/bulkDelete"

payload <- "{\n  \"id\": []\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/driving_types/bulkDelete")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/driving_types/bulkDelete') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"id\": []\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}}/driving_types/bulkDelete";

    let payload = json!({"id": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/driving_types/bulkDelete \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http DELETE {{baseUrl}}/driving_types/bulkDelete \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/driving_types/bulkDelete
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/driving_types/bulkDelete")! 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 Create driving type
{{baseUrl}}/driving_types
BODY json

{
  "company_id": "",
  "employee_price": "",
  "erp_id": "",
  "invoice_price": "",
  "name": "",
  "salary_id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/driving_types");

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  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/driving_types" {:content-type :json
                                                          :form-params {:company_id ""
                                                                        :employee_price ""
                                                                        :erp_id ""
                                                                        :invoice_price ""
                                                                        :name ""
                                                                        :salary_id ""}})
require "http/client"

url = "{{baseUrl}}/driving_types"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\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}}/driving_types"),
    Content = new StringContent("{\n  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\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}}/driving_types");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/driving_types"

	payload := strings.NewReader("{\n  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\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/driving_types HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 118

{
  "company_id": "",
  "employee_price": "",
  "erp_id": "",
  "invoice_price": "",
  "name": "",
  "salary_id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/driving_types")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/driving_types"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\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  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/driving_types")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/driving_types")
  .header("content-type", "application/json")
  .body("{\n  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  company_id: '',
  employee_price: '',
  erp_id: '',
  invoice_price: '',
  name: '',
  salary_id: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/driving_types');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/driving_types',
  headers: {'content-type': 'application/json'},
  data: {
    company_id: '',
    employee_price: '',
    erp_id: '',
    invoice_price: '',
    name: '',
    salary_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/driving_types';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"company_id":"","employee_price":"","erp_id":"","invoice_price":"","name":"","salary_id":""}'
};

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}}/driving_types',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "company_id": "",\n  "employee_price": "",\n  "erp_id": "",\n  "invoice_price": "",\n  "name": "",\n  "salary_id": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/driving_types")
  .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/driving_types',
  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({
  company_id: '',
  employee_price: '',
  erp_id: '',
  invoice_price: '',
  name: '',
  salary_id: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/driving_types',
  headers: {'content-type': 'application/json'},
  body: {
    company_id: '',
    employee_price: '',
    erp_id: '',
    invoice_price: '',
    name: '',
    salary_id: ''
  },
  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}}/driving_types');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  company_id: '',
  employee_price: '',
  erp_id: '',
  invoice_price: '',
  name: '',
  salary_id: ''
});

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}}/driving_types',
  headers: {'content-type': 'application/json'},
  data: {
    company_id: '',
    employee_price: '',
    erp_id: '',
    invoice_price: '',
    name: '',
    salary_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/driving_types';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"company_id":"","employee_price":"","erp_id":"","invoice_price":"","name":"","salary_id":""}'
};

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 = @{ @"company_id": @"",
                              @"employee_price": @"",
                              @"erp_id": @"",
                              @"invoice_price": @"",
                              @"name": @"",
                              @"salary_id": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/driving_types"]
                                                       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}}/driving_types" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/driving_types",
  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([
    'company_id' => '',
    'employee_price' => '',
    'erp_id' => '',
    'invoice_price' => '',
    'name' => '',
    'salary_id' => ''
  ]),
  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}}/driving_types', [
  'body' => '{
  "company_id": "",
  "employee_price": "",
  "erp_id": "",
  "invoice_price": "",
  "name": "",
  "salary_id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/driving_types');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'company_id' => '',
  'employee_price' => '',
  'erp_id' => '',
  'invoice_price' => '',
  'name' => '',
  'salary_id' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'company_id' => '',
  'employee_price' => '',
  'erp_id' => '',
  'invoice_price' => '',
  'name' => '',
  'salary_id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/driving_types');
$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}}/driving_types' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "company_id": "",
  "employee_price": "",
  "erp_id": "",
  "invoice_price": "",
  "name": "",
  "salary_id": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/driving_types' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "company_id": "",
  "employee_price": "",
  "erp_id": "",
  "invoice_price": "",
  "name": "",
  "salary_id": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/driving_types", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/driving_types"

payload = {
    "company_id": "",
    "employee_price": "",
    "erp_id": "",
    "invoice_price": "",
    "name": "",
    "salary_id": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/driving_types"

payload <- "{\n  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\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}}/driving_types")

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  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\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/driving_types') do |req|
  req.body = "{\n  \"company_id\": \"\",\n  \"employee_price\": \"\",\n  \"erp_id\": \"\",\n  \"invoice_price\": \"\",\n  \"name\": \"\",\n  \"salary_id\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/driving_types";

    let payload = json!({
        "company_id": "",
        "employee_price": "",
        "erp_id": "",
        "invoice_price": "",
        "name": "",
        "salary_id": ""
    });

    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}}/driving_types \
  --header 'content-type: application/json' \
  --data '{
  "company_id": "",
  "employee_price": "",
  "erp_id": "",
  "invoice_price": "",
  "name": "",
  "salary_id": ""
}'
echo '{
  "company_id": "",
  "employee_price": "",
  "erp_id": "",
  "invoice_price": "",
  "name": "",
  "salary_id": ""
}' |  \
  http POST {{baseUrl}}/driving_types \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "company_id": "",\n  "employee_price": "",\n  "erp_id": "",\n  "invoice_price": "",\n  "name": "",\n  "salary_id": ""\n}' \
  --output-document \
  - {{baseUrl}}/driving_types
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "company_id": "",
  "employee_price": "",
  "erp_id": "",
  "invoice_price": "",
  "name": "",
  "salary_id": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/driving_types")! 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 Delete driving type
{{baseUrl}}/driving_types/:driving_type_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/driving_types/:driving_type_id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/driving_types/:driving_type_id")
require "http/client"

url = "{{baseUrl}}/driving_types/:driving_type_id"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/driving_types/:driving_type_id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/driving_types/:driving_type_id");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/driving_types/:driving_type_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/driving_types/:driving_type_id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/driving_types/:driving_type_id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/driving_types/:driving_type_id"))
    .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}}/driving_types/:driving_type_id")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/driving_types/:driving_type_id")
  .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}}/driving_types/:driving_type_id');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/driving_types/:driving_type_id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/driving_types/:driving_type_id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/driving_types/:driving_type_id',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/driving_types/:driving_type_id")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/driving_types/:driving_type_id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/driving_types/:driving_type_id'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/driving_types/:driving_type_id');

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}}/driving_types/:driving_type_id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/driving_types/:driving_type_id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/driving_types/:driving_type_id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/driving_types/:driving_type_id" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/driving_types/:driving_type_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/driving_types/:driving_type_id');

echo $response->getBody();
setUrl('{{baseUrl}}/driving_types/:driving_type_id');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/driving_types/:driving_type_id');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/driving_types/:driving_type_id' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/driving_types/:driving_type_id' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/driving_types/:driving_type_id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/driving_types/:driving_type_id"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/driving_types/:driving_type_id"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/driving_types/:driving_type_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/driving_types/:driving_type_id') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/driving_types/:driving_type_id";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/driving_types/:driving_type_id
http DELETE {{baseUrl}}/driving_types/:driving_type_id
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/driving_types/:driving_type_id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/driving_types/:driving_type_id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT Edit driving type
{{baseUrl}}/driving_types/:driving_type_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/driving_types/:driving_type_id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/driving_types/:driving_type_id")
require "http/client"

url = "{{baseUrl}}/driving_types/:driving_type_id"

response = HTTP::Client.put url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/driving_types/:driving_type_id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/driving_types/:driving_type_id");
var request = new RestRequest("", Method.Put);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/driving_types/:driving_type_id"

	req, _ := http.NewRequest("PUT", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/driving_types/:driving_type_id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/driving_types/:driving_type_id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/driving_types/:driving_type_id"))
    .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}}/driving_types/:driving_type_id")
  .put(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/driving_types/:driving_type_id")
  .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}}/driving_types/:driving_type_id');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/driving_types/:driving_type_id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/driving_types/:driving_type_id';
const options = {method: 'PUT'};

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}}/driving_types/:driving_type_id',
  method: 'PUT',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/driving_types/:driving_type_id")
  .put(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/driving_types/:driving_type_id',
  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: 'PUT',
  url: '{{baseUrl}}/driving_types/:driving_type_id'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/driving_types/:driving_type_id');

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}}/driving_types/:driving_type_id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/driving_types/:driving_type_id';
const options = {method: 'PUT'};

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}}/driving_types/:driving_type_id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];

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}}/driving_types/:driving_type_id" in

Client.call `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/driving_types/:driving_type_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/driving_types/:driving_type_id');

echo $response->getBody();
setUrl('{{baseUrl}}/driving_types/:driving_type_id');
$request->setMethod(HTTP_METH_PUT);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/driving_types/:driving_type_id');
$request->setRequestMethod('PUT');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/driving_types/:driving_type_id' -Method PUT 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/driving_types/:driving_type_id' -Method PUT 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("PUT", "/baseUrl/driving_types/:driving_type_id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/driving_types/:driving_type_id"

response = requests.put(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/driving_types/:driving_type_id"

response <- VERB("PUT", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/driving_types/:driving_type_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/driving_types/:driving_type_id') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/driving_types/:driving_type_id";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/driving_types/:driving_type_id
http PUT {{baseUrl}}/driving_types/:driving_type_id
wget --quiet \
  --method PUT \
  --output-document \
  - {{baseUrl}}/driving_types/:driving_type_id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/driving_types/:driving_type_id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"

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 the driving types of the company
{{baseUrl}}/driving_types
QUERY PARAMS

api_token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/driving_types" {:query-params {:api_token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D"

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}}/driving_types?api_token=%7B%7BapiKey%7D%7D"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D"

	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/driving_types?api_token=%7B%7BapiKey%7D%7D HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D"))
    .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}}/driving_types?api_token=%7B%7BapiKey%7D%7D")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D")
  .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}}/driving_types?api_token=%7B%7BapiKey%7D%7D');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/driving_types',
  params: {api_token: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D';
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}}/driving_types?api_token=%7B%7BapiKey%7D%7D',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/driving_types?api_token=%7B%7BapiKey%7D%7D',
  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}}/driving_types',
  qs: {api_token: '{{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}}/driving_types');

req.query({
  api_token: '{{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}}/driving_types',
  params: {api_token: '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D';
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}}/driving_types?api_token=%7B%7BapiKey%7D%7D"]
                                                       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}}/driving_types?api_token=%7B%7BapiKey%7D%7D" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D",
  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}}/driving_types?api_token=%7B%7BapiKey%7D%7D');

echo $response->getBody();
setUrl('{{baseUrl}}/driving_types');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'api_token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/driving_types');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'api_token' => '{{apiKey}}'
]));

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/driving_types?api_token=%7B%7BapiKey%7D%7D")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/driving_types"

querystring = {"api_token":"{{apiKey}}"}

response = requests.get(url, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/driving_types"

queryString <- list(api_token = "{{apiKey}}")

response <- VERB("GET", url, query = queryString, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D")

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/driving_types') do |req|
  req.params['api_token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/driving_types";

    let querystring = [
        ("api_token", "{{apiKey}}"),
    ];

    let client = reqwest::Client::new();
    let response = client.get(url)
        .query(&querystring)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url '{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D'
http GET '{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D'
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/driving_types?api_token=%7B%7BapiKey%7D%7D")! 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 View driving type
{{baseUrl}}/driving_types/:driving_type_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

driving_type_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/driving_types/:driving_type_id?driving_type_id=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/driving_types/:driving_type_id" {:headers {:x-auth-token "{{apiKey}}"}
                                                                          :query-params {:driving_type_id ""}})
require "http/client"

url = "{{baseUrl}}/driving_types/:driving_type_id?driving_type_id="
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/driving_types/:driving_type_id?driving_type_id="),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/driving_types/:driving_type_id?driving_type_id=");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/driving_types/:driving_type_id?driving_type_id="

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/driving_types/:driving_type_id?driving_type_id= HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/driving_types/:driving_type_id?driving_type_id=")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/driving_types/:driving_type_id?driving_type_id="))
    .header("x-auth-token", "{{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}}/driving_types/:driving_type_id?driving_type_id=")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/driving_types/:driving_type_id?driving_type_id=")
  .header("x-auth-token", "{{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}}/driving_types/:driving_type_id?driving_type_id=');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/driving_types/:driving_type_id',
  params: {driving_type_id: ''},
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/driving_types/:driving_type_id?driving_type_id=';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/driving_types/:driving_type_id?driving_type_id=',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/driving_types/:driving_type_id?driving_type_id=")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/driving_types/:driving_type_id?driving_type_id=',
  headers: {
    'x-auth-token': '{{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}}/driving_types/:driving_type_id',
  qs: {driving_type_id: ''},
  headers: {'x-auth-token': '{{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}}/driving_types/:driving_type_id');

req.query({
  driving_type_id: ''
});

req.headers({
  'x-auth-token': '{{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}}/driving_types/:driving_type_id',
  params: {driving_type_id: ''},
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/driving_types/:driving_type_id?driving_type_id=';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/driving_types/:driving_type_id?driving_type_id="]
                                                       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}}/driving_types/:driving_type_id?driving_type_id=" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/driving_types/:driving_type_id?driving_type_id=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/driving_types/:driving_type_id?driving_type_id=', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/driving_types/:driving_type_id');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'driving_type_id' => ''
]);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/driving_types/:driving_type_id');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'driving_type_id' => ''
]));

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/driving_types/:driving_type_id?driving_type_id=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/driving_types/:driving_type_id?driving_type_id=' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/driving_types/:driving_type_id?driving_type_id=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/driving_types/:driving_type_id"

querystring = {"driving_type_id":""}

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/driving_types/:driving_type_id"

queryString <- list(driving_type_id = "")

response <- VERB("GET", url, query = queryString, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/driving_types/:driving_type_id?driving_type_id=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/driving_types/:driving_type_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.params['driving_type_id'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/driving_types/:driving_type_id";

    let querystring = [
        ("driving_type_id", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/driving_types/:driving_type_id?driving_type_id=' \
  --header 'x-auth-token: {{apiKey}}'
http GET '{{baseUrl}}/driving_types/:driving_type_id?driving_type_id=' \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/driving_types/:driving_type_id?driving_type_id='
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/driving_types/:driving_type_id?driving_type_id=")! 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 Used to retrieve details about the logged in user's hours
{{baseUrl}}/employee_hours
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

date_from
date_to
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/employee_hours?date_from=&date_to=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/employee_hours" {:headers {:x-auth-token "{{apiKey}}"}
                                                          :query-params {:date_from ""
                                                                         :date_to ""}})
require "http/client"

url = "{{baseUrl}}/employee_hours?date_from=&date_to="
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/employee_hours?date_from=&date_to="),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/employee_hours?date_from=&date_to=");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/employee_hours?date_from=&date_to="

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/employee_hours?date_from=&date_to= HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/employee_hours?date_from=&date_to=")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/employee_hours?date_from=&date_to="))
    .header("x-auth-token", "{{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}}/employee_hours?date_from=&date_to=")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/employee_hours?date_from=&date_to=")
  .header("x-auth-token", "{{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}}/employee_hours?date_from=&date_to=');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/employee_hours',
  params: {date_from: '', date_to: ''},
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/employee_hours?date_from=&date_to=';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/employee_hours?date_from=&date_to=',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/employee_hours?date_from=&date_to=")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/employee_hours?date_from=&date_to=',
  headers: {
    'x-auth-token': '{{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}}/employee_hours',
  qs: {date_from: '', date_to: ''},
  headers: {'x-auth-token': '{{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}}/employee_hours');

req.query({
  date_from: '',
  date_to: ''
});

req.headers({
  'x-auth-token': '{{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}}/employee_hours',
  params: {date_from: '', date_to: ''},
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/employee_hours?date_from=&date_to=';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/employee_hours?date_from=&date_to="]
                                                       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}}/employee_hours?date_from=&date_to=" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/employee_hours?date_from=&date_to=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/employee_hours?date_from=&date_to=', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/employee_hours');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'date_from' => '',
  'date_to' => ''
]);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/employee_hours');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'date_from' => '',
  'date_to' => ''
]));

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/employee_hours?date_from=&date_to=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/employee_hours?date_from=&date_to=' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/employee_hours?date_from=&date_to=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/employee_hours"

querystring = {"date_from":"","date_to":""}

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/employee_hours"

queryString <- list(
  date_from = "",
  date_to = ""
)

response <- VERB("GET", url, query = queryString, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/employee_hours?date_from=&date_to=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/employee_hours') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.params['date_from'] = ''
  req.params['date_to'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/employee_hours";

    let querystring = [
        ("date_from", ""),
        ("date_to", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/employee_hours?date_from=&date_to=' \
  --header 'x-auth-token: {{apiKey}}'
http GET '{{baseUrl}}/employee_hours?date_from=&date_to=' \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/employee_hours?date_from=&date_to='
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/employee_hours?date_from=&date_to=")! 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 Check if user is available at given datetime range
{{baseUrl}}/events/is_user_free
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
start
end
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/events/is_user_free?user_id=&start=&end=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/events/is_user_free" {:headers {:x-auth-token "{{apiKey}}"}
                                                               :query-params {:user_id ""
                                                                              :start ""
                                                                              :end ""}})
require "http/client"

url = "{{baseUrl}}/events/is_user_free?user_id=&start=&end="
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/events/is_user_free?user_id=&start=&end="),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/events/is_user_free?user_id=&start=&end=");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/events/is_user_free?user_id=&start=&end="

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/events/is_user_free?user_id=&start=&end= HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/events/is_user_free?user_id=&start=&end=")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/events/is_user_free?user_id=&start=&end="))
    .header("x-auth-token", "{{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}}/events/is_user_free?user_id=&start=&end=")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/events/is_user_free?user_id=&start=&end=")
  .header("x-auth-token", "{{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}}/events/is_user_free?user_id=&start=&end=');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/events/is_user_free',
  params: {user_id: '', start: '', end: ''},
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/events/is_user_free?user_id=&start=&end=';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/events/is_user_free?user_id=&start=&end=',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/events/is_user_free?user_id=&start=&end=")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/events/is_user_free?user_id=&start=&end=',
  headers: {
    'x-auth-token': '{{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}}/events/is_user_free',
  qs: {user_id: '', start: '', end: ''},
  headers: {'x-auth-token': '{{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}}/events/is_user_free');

req.query({
  user_id: '',
  start: '',
  end: ''
});

req.headers({
  'x-auth-token': '{{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}}/events/is_user_free',
  params: {user_id: '', start: '', end: ''},
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/events/is_user_free?user_id=&start=&end=';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/events/is_user_free?user_id=&start=&end="]
                                                       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}}/events/is_user_free?user_id=&start=&end=" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/events/is_user_free?user_id=&start=&end=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/events/is_user_free?user_id=&start=&end=', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/events/is_user_free');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'user_id' => '',
  'start' => '',
  'end' => ''
]);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/events/is_user_free');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'user_id' => '',
  'start' => '',
  'end' => ''
]));

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/events/is_user_free?user_id=&start=&end=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/events/is_user_free?user_id=&start=&end=' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/events/is_user_free?user_id=&start=&end=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/events/is_user_free"

querystring = {"user_id":"","start":"","end":""}

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/events/is_user_free"

queryString <- list(
  user_id = "",
  start = "",
  end = ""
)

response <- VERB("GET", url, query = queryString, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/events/is_user_free?user_id=&start=&end=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/events/is_user_free') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.params['user_id'] = ''
  req.params['start'] = ''
  req.params['end'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/events/is_user_free";

    let querystring = [
        ("user_id", ""),
        ("start", ""),
        ("end", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/events/is_user_free?user_id=&start=&end=' \
  --header 'x-auth-token: {{apiKey}}'
http GET '{{baseUrl}}/events/is_user_free?user_id=&start=&end=' \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/events/is_user_free?user_id=&start=&end='
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/events/is_user_free?user_id=&start=&end=")! 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 Create event
{{baseUrl}}/events
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "description": "",
  "end": "",
  "name": "",
  "project_id": "",
  "start": "",
  "user_id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/events");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/events" {:headers {:x-auth-token "{{apiKey}}"}
                                                   :content-type :json
                                                   :form-params {:description ""
                                                                 :end ""
                                                                 :name ""
                                                                 :project_id ""
                                                                 :start ""
                                                                 :user_id ""}})
require "http/client"

url = "{{baseUrl}}/events"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\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}}/events"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\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}}/events");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/events"

	payload := strings.NewReader("{\n  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/events HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 102

{
  "description": "",
  "end": "",
  "name": "",
  "project_id": "",
  "start": "",
  "user_id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/events")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/events"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\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  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/events")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/events")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  description: '',
  end: '',
  name: '',
  project_id: '',
  start: '',
  user_id: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/events');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/events',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {description: '', end: '', name: '', project_id: '', start: '', user_id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/events';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"description":"","end":"","name":"","project_id":"","start":"","user_id":""}'
};

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}}/events',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "description": "",\n  "end": "",\n  "name": "",\n  "project_id": "",\n  "start": "",\n  "user_id": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/events")
  .post(body)
  .addHeader("x-auth-token", "{{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/events',
  headers: {
    'x-auth-token': '{{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({description: '', end: '', name: '', project_id: '', start: '', user_id: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/events',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {description: '', end: '', name: '', project_id: '', start: '', user_id: ''},
  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}}/events');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  description: '',
  end: '',
  name: '',
  project_id: '',
  start: '',
  user_id: ''
});

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}}/events',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {description: '', end: '', name: '', project_id: '', start: '', user_id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/events';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"description":"","end":"","name":"","project_id":"","start":"","user_id":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"description": @"",
                              @"end": @"",
                              @"name": @"",
                              @"project_id": @"",
                              @"start": @"",
                              @"user_id": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/events"]
                                                       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}}/events" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/events",
  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([
    'description' => '',
    'end' => '',
    'name' => '',
    'project_id' => '',
    'start' => '',
    'user_id' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/events', [
  'body' => '{
  "description": "",
  "end": "",
  "name": "",
  "project_id": "",
  "start": "",
  "user_id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/events');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'description' => '',
  'end' => '',
  'name' => '',
  'project_id' => '',
  'start' => '',
  'user_id' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'description' => '',
  'end' => '',
  'name' => '',
  'project_id' => '',
  'start' => '',
  'user_id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/events');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/events' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "description": "",
  "end": "",
  "name": "",
  "project_id": "",
  "start": "",
  "user_id": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/events' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "description": "",
  "end": "",
  "name": "",
  "project_id": "",
  "start": "",
  "user_id": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/events", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/events"

payload = {
    "description": "",
    "end": "",
    "name": "",
    "project_id": "",
    "start": "",
    "user_id": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/events"

payload <- "{\n  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/events")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\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/events') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"description\": \"\",\n  \"end\": \"\",\n  \"name\": \"\",\n  \"project_id\": \"\",\n  \"start\": \"\",\n  \"user_id\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/events";

    let payload = json!({
        "description": "",
        "end": "",
        "name": "",
        "project_id": "",
        "start": "",
        "user_id": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/events \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "description": "",
  "end": "",
  "name": "",
  "project_id": "",
  "start": "",
  "user_id": ""
}'
echo '{
  "description": "",
  "end": "",
  "name": "",
  "project_id": "",
  "start": "",
  "user_id": ""
}' |  \
  http POST {{baseUrl}}/events \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "description": "",\n  "end": "",\n  "name": "",\n  "project_id": "",\n  "start": "",\n  "user_id": ""\n}' \
  --output-document \
  - {{baseUrl}}/events
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "description": "",
  "end": "",
  "name": "",
  "project_id": "",
  "start": "",
  "user_id": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/events")! 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 Delete event
{{baseUrl}}/events/:event_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

event_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/events/:event_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/events/:event_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/events/:event_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/events/:event_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/events/:event_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/events/:event_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/events/:event_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/events/:event_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/events/:event_id"))
    .header("x-auth-token", "{{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}}/events/:event_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/events/:event_id")
  .header("x-auth-token", "{{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}}/events/:event_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/events/:event_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/events/:event_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/events/:event_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/events/:event_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/events/:event_id',
  headers: {
    'x-auth-token': '{{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}}/events/:event_id',
  headers: {'x-auth-token': '{{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}}/events/:event_id');

req.headers({
  'x-auth-token': '{{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}}/events/:event_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/events/:event_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/events/:event_id"]
                                                       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}}/events/:event_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/events/:event_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/events/:event_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/events/:event_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/events/:event_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/events/:event_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/events/:event_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/events/:event_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/events/:event_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/events/:event_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/events/:event_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/events/:event_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/events/:event_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/events/:event_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/events/:event_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/events/:event_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/events/:event_id")! 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()
PUT Edit event
{{baseUrl}}/events/:event_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

event_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/events/:event_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/events/:event_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/events/:event_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/events/:event_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/events/:event_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/events/:event_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/events/:event_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/events/:event_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/events/:event_id"))
    .header("x-auth-token", "{{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}}/events/:event_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/events/:event_id")
  .header("x-auth-token", "{{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}}/events/:event_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/events/:event_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/events/:event_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/events/:event_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/events/:event_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/events/:event_id',
  headers: {
    'x-auth-token': '{{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}}/events/:event_id',
  headers: {'x-auth-token': '{{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}}/events/:event_id');

req.headers({
  'x-auth-token': '{{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}}/events/:event_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/events/:event_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/events/:event_id"]
                                                       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}}/events/:event_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/events/:event_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/events/:event_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/events/:event_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/events/:event_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/events/:event_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/events/:event_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/events/:event_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/events/:event_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/events/:event_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/events/:event_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/events/:event_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/events/:event_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/events/:event_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/events/:event_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/events/:event_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/events/:event_id")! 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()
GET Show event
{{baseUrl}}/events/:event_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

event_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/events/:event_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/events/:event_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/events/:event_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/events/:event_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/events/:event_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/events/:event_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/events/:event_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/events/:event_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/events/:event_id"))
    .header("x-auth-token", "{{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}}/events/:event_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/events/:event_id")
  .header("x-auth-token", "{{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}}/events/:event_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/events/:event_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/events/:event_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/events/:event_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/events/:event_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/events/:event_id',
  headers: {
    'x-auth-token': '{{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}}/events/:event_id',
  headers: {'x-auth-token': '{{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}}/events/:event_id');

req.headers({
  'x-auth-token': '{{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}}/events/:event_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/events/:event_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/events/:event_id"]
                                                       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}}/events/:event_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/events/:event_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/events/:event_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/events/:event_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/events/:event_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/events/:event_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/events/:event_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/events/:event_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/events/:event_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/events/:event_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/events/:event_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/events/:event_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/events/:event_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/events/:event_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/events/:event_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/events/:event_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/events/:event_id")! 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 Show list of events
{{baseUrl}}/events
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/events");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/events" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/events"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/events"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/events");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/events"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/events HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/events")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/events"))
    .header("x-auth-token", "{{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}}/events")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/events")
  .header("x-auth-token", "{{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}}/events');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/events',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/events';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/events',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/events")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/events',
  headers: {
    'x-auth-token': '{{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}}/events',
  headers: {'x-auth-token': '{{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}}/events');

req.headers({
  'x-auth-token': '{{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}}/events',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/events';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/events"]
                                                       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}}/events" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/events",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/events', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/events');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/events');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/events' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/events' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/events", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/events"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/events"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/events")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/events') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/events";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/events \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/events \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/events
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/events")! 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 Show OIOUBL file
{{baseUrl}}/expenses/:expense_id/original_files/:file_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

expense_id
file_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expenses/:expense_id/original_files/:file_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/expenses/:expense_id/original_files/:file_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/expenses/:expense_id/original_files/:file_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expenses/:expense_id/original_files/:file_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expenses/:expense_id/original_files/:file_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expenses/:expense_id/original_files/:file_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/expenses/:expense_id/original_files/:file_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/expenses/:expense_id/original_files/:file_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expenses/:expense_id/original_files/:file_id"))
    .header("x-auth-token", "{{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}}/expenses/:expense_id/original_files/:file_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/expenses/:expense_id/original_files/:file_id")
  .header("x-auth-token", "{{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}}/expenses/:expense_id/original_files/:file_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/expenses/:expense_id/original_files/:file_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expenses/:expense_id/original_files/:file_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/expenses/:expense_id/original_files/:file_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expenses/:expense_id/original_files/:file_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expenses/:expense_id/original_files/:file_id',
  headers: {
    'x-auth-token': '{{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}}/expenses/:expense_id/original_files/:file_id',
  headers: {'x-auth-token': '{{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}}/expenses/:expense_id/original_files/:file_id');

req.headers({
  'x-auth-token': '{{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}}/expenses/:expense_id/original_files/:file_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expenses/:expense_id/original_files/:file_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expenses/:expense_id/original_files/:file_id"]
                                                       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}}/expenses/:expense_id/original_files/:file_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expenses/:expense_id/original_files/:file_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/expenses/:expense_id/original_files/:file_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expenses/:expense_id/original_files/:file_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expenses/:expense_id/original_files/:file_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expenses/:expense_id/original_files/:file_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expenses/:expense_id/original_files/:file_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/expenses/:expense_id/original_files/:file_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expenses/:expense_id/original_files/:file_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expenses/:expense_id/original_files/:file_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expenses/:expense_id/original_files/:file_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/expenses/:expense_id/original_files/:file_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expenses/:expense_id/original_files/:file_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expenses/:expense_id/original_files/:file_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/expenses/:expense_id/original_files/:file_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/expenses/:expense_id/original_files/:file_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expenses/:expense_id/original_files/:file_id")! 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 Show list of all OIOUBL files for the expense
{{baseUrl}}/expenses/:expense_id/original_files
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

expense_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expenses/:expense_id/original_files");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/expenses/:expense_id/original_files" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/expenses/:expense_id/original_files"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expenses/:expense_id/original_files"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expenses/:expense_id/original_files");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expenses/:expense_id/original_files"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/expenses/:expense_id/original_files HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/expenses/:expense_id/original_files")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expenses/:expense_id/original_files"))
    .header("x-auth-token", "{{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}}/expenses/:expense_id/original_files")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/expenses/:expense_id/original_files")
  .header("x-auth-token", "{{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}}/expenses/:expense_id/original_files');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/expenses/:expense_id/original_files',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expenses/:expense_id/original_files';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/expenses/:expense_id/original_files',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expenses/:expense_id/original_files")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expenses/:expense_id/original_files',
  headers: {
    'x-auth-token': '{{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}}/expenses/:expense_id/original_files',
  headers: {'x-auth-token': '{{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}}/expenses/:expense_id/original_files');

req.headers({
  'x-auth-token': '{{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}}/expenses/:expense_id/original_files',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expenses/:expense_id/original_files';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expenses/:expense_id/original_files"]
                                                       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}}/expenses/:expense_id/original_files" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expenses/:expense_id/original_files",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/expenses/:expense_id/original_files', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expenses/:expense_id/original_files');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expenses/:expense_id/original_files');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expenses/:expense_id/original_files' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expenses/:expense_id/original_files' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/expenses/:expense_id/original_files", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expenses/:expense_id/original_files"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expenses/:expense_id/original_files"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expenses/:expense_id/original_files")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/expenses/:expense_id/original_files') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expenses/:expense_id/original_files";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expenses/:expense_id/original_files \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/expenses/:expense_id/original_files \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/expenses/:expense_id/original_files
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expenses/:expense_id/original_files")! 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 file to expense
{{baseUrl}}/expense_files
HEADERS

X-Auth-Token
{{apiKey}}
BODY multipartForm

Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expense_files");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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=\"description\"\r\n\r\n\r\n-----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}}/expense_files" {:headers {:x-auth-token "{{apiKey}}"}
                                                          :multipart [{:name "description"
                                                                       :content ""} {:name "file"
                                                                       :content ""}]})
require "http/client"

url = "{{baseUrl}}/expense_files"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "multipart/form-data; boundary=---011000010111000001101001"
}
reqBody = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"description\"\r\n\r\n\r\n-----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}}/expense_files"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new MultipartFormDataContent
    {
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "description",
                }
            }
        },
        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}}/expense_files");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001");
request.AddParameter("multipart/form-data; boundary=---011000010111000001101001", "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"description\"\r\n\r\n\r\n-----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}}/expense_files"

	payload := strings.NewReader("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"description\"\r\n\r\n\r\n-----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("x-auth-token", "{{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/expense_files HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: multipart/form-data; boundary=---011000010111000001101001
Host: example.com
Content-Length: 200

-----011000010111000001101001
Content-Disposition: form-data; name="description"


-----011000010111000001101001
Content-Disposition: form-data; name="file"


-----011000010111000001101001--
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/expense_files")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .setBody("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"description\"\r\n\r\n\r\n-----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}}/expense_files"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
    .method("POST", HttpRequest.BodyPublishers.ofString("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"description\"\r\n\r\n\r\n-----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=\"description\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");
Request request = new Request.Builder()
  .url("{{baseUrl}}/expense_files")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/expense_files")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .body("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"description\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
  .asString();
const data = new FormData();
data.append('description', '');
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}}/expense_files');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const form = new FormData();
form.append('description', '');
form.append('file', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/expense_files',
  headers: {
    'x-auth-token': '{{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}}/expense_files';
const form = new FormData();
form.append('description', '');
form.append('file', '');

const options = {method: 'POST', headers: {'x-auth-token': '{{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('description', '');
form.append('file', '');

const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/expense_files',
  method: 'POST',
  headers: {
    'x-auth-token': '{{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=\"description\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
val request = Request.Builder()
  .url("{{baseUrl}}/expense_files")
  .post(body)
  .addHeader("x-auth-token", "{{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/expense_files',
  headers: {
    'x-auth-token': '{{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="description"\r\n\r\n\r\n-----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}}/expense_files',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  formData: {description: '', 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}}/expense_files');

req.headers({
  'x-auth-token': '{{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}}/expense_files',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  data: '-----011000010111000001101001\r\nContent-Disposition: form-data; name="description"\r\n\r\n\r\n-----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('description', '');
formData.append('file', '');

const url = '{{baseUrl}}/expense_files';
const options = {method: 'POST', headers: {'x-auth-token': '{{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 = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"multipart/form-data; boundary=---011000010111000001101001" };
NSArray *parameters = @[ @{ @"name": @"description", @"value": @"" },
                         @{ @"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}}/expense_files"]
                                                       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}}/expense_files" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "multipart/form-data; boundary=---011000010111000001101001");
] in
let body = Cohttp_lwt_body.of_string "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"description\"\r\n\r\n\r\n-----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}}/expense_files",
  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=\"description\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n",
  CURLOPT_HTTPHEADER => [
    "content-type: multipart/form-data; boundary=---011000010111000001101001",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/expense_files', [
  'headers' => [
    'content-type' => 'multipart/form-data; boundary=---011000010111000001101001',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expense_files');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'multipart/form-data; boundary=---011000010111000001101001'
]);

$request->setBody('-----011000010111000001101001
Content-Disposition: form-data; name="description"


-----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}}/expense_files');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expense_files' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="description"


-----011000010111000001101001
Content-Disposition: form-data; name="file"


-----011000010111000001101001--
'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expense_files' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="description"


-----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=\"description\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "multipart/form-data; boundary=---011000010111000001101001"
}

conn.request("POST", "/baseUrl/expense_files", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expense_files"

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"description\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "multipart/form-data; boundary=---011000010111000001101001"
}

response = requests.post(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expense_files"

payload <- "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"description\"\r\n\r\n\r\n-----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('x-auth-token' = '{{apiKey}}'), content_type("multipart/form-data"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expense_files")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'multipart/form-data; boundary=---011000010111000001101001'
request.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"description\"\r\n\r\n\r\n-----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/expense_files') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"description\"\r\n\r\n\r\n-----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}}/expense_files";

    let form = reqwest::multipart::Form::new()
        .text("description", "")
        .text("file", "");
    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expense_files \
  --header 'content-type: multipart/form-data' \
  --header 'x-auth-token: {{apiKey}}' \
  --form description= \
  --form file=
echo '-----011000010111000001101001
Content-Disposition: form-data; name="description"


-----011000010111000001101001
Content-Disposition: form-data; name="file"


-----011000010111000001101001--
' |  \
  http POST {{baseUrl}}/expense_files \
  content-type:'multipart/form-data; boundary=---011000010111000001101001' \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: multipart/form-data; boundary=---011000010111000001101001' \
  --body-data '-----011000010111000001101001\r\nContent-Disposition: form-data; name="description"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="file"\r\n\r\n\r\n-----011000010111000001101001--\r\n' \
  --output-document \
  - {{baseUrl}}/expense_files
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "multipart/form-data; boundary=---011000010111000001101001"
]
let parameters = [
  [
    "name": "description",
    "value": ""
  ],
  [
    "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}}/expense_files")! 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 Delete file
{{baseUrl}}/expense_files/:expense_file_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

expense_file_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expense_files/:expense_file_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/expense_files/:expense_file_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/expense_files/:expense_file_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expense_files/:expense_file_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expense_files/:expense_file_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expense_files/:expense_file_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/expense_files/:expense_file_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/expense_files/:expense_file_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expense_files/:expense_file_id"))
    .header("x-auth-token", "{{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}}/expense_files/:expense_file_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/expense_files/:expense_file_id")
  .header("x-auth-token", "{{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}}/expense_files/:expense_file_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/expense_files/:expense_file_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expense_files/:expense_file_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/expense_files/:expense_file_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expense_files/:expense_file_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expense_files/:expense_file_id',
  headers: {
    'x-auth-token': '{{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}}/expense_files/:expense_file_id',
  headers: {'x-auth-token': '{{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}}/expense_files/:expense_file_id');

req.headers({
  'x-auth-token': '{{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}}/expense_files/:expense_file_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expense_files/:expense_file_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expense_files/:expense_file_id"]
                                                       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}}/expense_files/:expense_file_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expense_files/:expense_file_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/expense_files/:expense_file_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expense_files/:expense_file_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expense_files/:expense_file_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expense_files/:expense_file_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expense_files/:expense_file_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/expense_files/:expense_file_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expense_files/:expense_file_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expense_files/:expense_file_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expense_files/:expense_file_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/expense_files/:expense_file_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expense_files/:expense_file_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expense_files/:expense_file_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/expense_files/:expense_file_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/expense_files/:expense_file_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expense_files/:expense_file_id")! 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()
PUT Edit file
{{baseUrl}}/expense_files/:expense_file_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

expense_file_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expense_files/:expense_file_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/expense_files/:expense_file_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/expense_files/:expense_file_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expense_files/:expense_file_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expense_files/:expense_file_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expense_files/:expense_file_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/expense_files/:expense_file_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/expense_files/:expense_file_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expense_files/:expense_file_id"))
    .header("x-auth-token", "{{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}}/expense_files/:expense_file_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/expense_files/:expense_file_id")
  .header("x-auth-token", "{{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}}/expense_files/:expense_file_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/expense_files/:expense_file_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expense_files/:expense_file_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/expense_files/:expense_file_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expense_files/:expense_file_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expense_files/:expense_file_id',
  headers: {
    'x-auth-token': '{{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}}/expense_files/:expense_file_id',
  headers: {'x-auth-token': '{{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}}/expense_files/:expense_file_id');

req.headers({
  'x-auth-token': '{{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}}/expense_files/:expense_file_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expense_files/:expense_file_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expense_files/:expense_file_id"]
                                                       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}}/expense_files/:expense_file_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expense_files/:expense_file_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/expense_files/:expense_file_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expense_files/:expense_file_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expense_files/:expense_file_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expense_files/:expense_file_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expense_files/:expense_file_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/expense_files/:expense_file_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expense_files/:expense_file_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expense_files/:expense_file_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expense_files/:expense_file_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/expense_files/:expense_file_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expense_files/:expense_file_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expense_files/:expense_file_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/expense_files/:expense_file_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/expense_files/:expense_file_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expense_files/:expense_file_id")! 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()
GET Show file
{{baseUrl}}/expense_files/:expense_file_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

expense_file_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expense_files/:expense_file_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/expense_files/:expense_file_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/expense_files/:expense_file_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expense_files/:expense_file_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expense_files/:expense_file_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expense_files/:expense_file_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/expense_files/:expense_file_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/expense_files/:expense_file_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expense_files/:expense_file_id"))
    .header("x-auth-token", "{{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}}/expense_files/:expense_file_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/expense_files/:expense_file_id")
  .header("x-auth-token", "{{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}}/expense_files/:expense_file_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/expense_files/:expense_file_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expense_files/:expense_file_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/expense_files/:expense_file_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expense_files/:expense_file_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expense_files/:expense_file_id',
  headers: {
    'x-auth-token': '{{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}}/expense_files/:expense_file_id',
  headers: {'x-auth-token': '{{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}}/expense_files/:expense_file_id');

req.headers({
  'x-auth-token': '{{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}}/expense_files/:expense_file_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expense_files/:expense_file_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expense_files/:expense_file_id"]
                                                       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}}/expense_files/:expense_file_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expense_files/:expense_file_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/expense_files/:expense_file_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expense_files/:expense_file_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expense_files/:expense_file_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expense_files/:expense_file_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expense_files/:expense_file_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/expense_files/:expense_file_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expense_files/:expense_file_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expense_files/:expense_file_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expense_files/:expense_file_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/expense_files/:expense_file_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expense_files/:expense_file_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expense_files/:expense_file_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/expense_files/:expense_file_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/expense_files/:expense_file_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expense_files/:expense_file_id")! 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 Show list of expense files
{{baseUrl}}/expense_files
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expense_files");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/expense_files" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/expense_files"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expense_files"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expense_files");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expense_files"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/expense_files HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/expense_files")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expense_files"))
    .header("x-auth-token", "{{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}}/expense_files")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/expense_files")
  .header("x-auth-token", "{{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}}/expense_files');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/expense_files',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expense_files';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/expense_files',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expense_files")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expense_files',
  headers: {
    'x-auth-token': '{{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}}/expense_files',
  headers: {'x-auth-token': '{{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}}/expense_files');

req.headers({
  'x-auth-token': '{{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}}/expense_files',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expense_files';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expense_files"]
                                                       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}}/expense_files" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expense_files",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/expense_files', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expense_files');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expense_files');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expense_files' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expense_files' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/expense_files", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expense_files"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expense_files"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expense_files")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/expense_files') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expense_files";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expense_files \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/expense_files \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/expense_files
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expense_files")! 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 line to expense
{{baseUrl}}/expense_lines
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "buying_price": "",
  "currency_id": "",
  "expense_id": "",
  "quantity": 0,
  "selling_price": "",
  "text": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expense_lines");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/expense_lines" {:headers {:x-auth-token "{{apiKey}}"}
                                                          :content-type :json
                                                          :form-params {:buying_price ""
                                                                        :currency_id ""
                                                                        :expense_id ""
                                                                        :quantity 0
                                                                        :selling_price ""
                                                                        :text ""}})
require "http/client"

url = "{{baseUrl}}/expense_lines"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\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}}/expense_lines"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\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}}/expense_lines");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expense_lines"

	payload := strings.NewReader("{\n  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/expense_lines HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 119

{
  "buying_price": "",
  "currency_id": "",
  "expense_id": "",
  "quantity": 0,
  "selling_price": "",
  "text": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/expense_lines")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expense_lines"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\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  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/expense_lines")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/expense_lines")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  buying_price: '',
  currency_id: '',
  expense_id: '',
  quantity: 0,
  selling_price: '',
  text: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/expense_lines');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/expense_lines',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    buying_price: '',
    currency_id: '',
    expense_id: '',
    quantity: 0,
    selling_price: '',
    text: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expense_lines';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"buying_price":"","currency_id":"","expense_id":"","quantity":0,"selling_price":"","text":""}'
};

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}}/expense_lines',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "buying_price": "",\n  "currency_id": "",\n  "expense_id": "",\n  "quantity": 0,\n  "selling_price": "",\n  "text": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/expense_lines")
  .post(body)
  .addHeader("x-auth-token", "{{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/expense_lines',
  headers: {
    'x-auth-token': '{{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({
  buying_price: '',
  currency_id: '',
  expense_id: '',
  quantity: 0,
  selling_price: '',
  text: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/expense_lines',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    buying_price: '',
    currency_id: '',
    expense_id: '',
    quantity: 0,
    selling_price: '',
    text: ''
  },
  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}}/expense_lines');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  buying_price: '',
  currency_id: '',
  expense_id: '',
  quantity: 0,
  selling_price: '',
  text: ''
});

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}}/expense_lines',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    buying_price: '',
    currency_id: '',
    expense_id: '',
    quantity: 0,
    selling_price: '',
    text: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expense_lines';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"buying_price":"","currency_id":"","expense_id":"","quantity":0,"selling_price":"","text":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"buying_price": @"",
                              @"currency_id": @"",
                              @"expense_id": @"",
                              @"quantity": @0,
                              @"selling_price": @"",
                              @"text": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expense_lines"]
                                                       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}}/expense_lines" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expense_lines",
  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([
    'buying_price' => '',
    'currency_id' => '',
    'expense_id' => '',
    'quantity' => 0,
    'selling_price' => '',
    'text' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/expense_lines', [
  'body' => '{
  "buying_price": "",
  "currency_id": "",
  "expense_id": "",
  "quantity": 0,
  "selling_price": "",
  "text": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expense_lines');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'buying_price' => '',
  'currency_id' => '',
  'expense_id' => '',
  'quantity' => 0,
  'selling_price' => '',
  'text' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'buying_price' => '',
  'currency_id' => '',
  'expense_id' => '',
  'quantity' => 0,
  'selling_price' => '',
  'text' => ''
]));
$request->setRequestUrl('{{baseUrl}}/expense_lines');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expense_lines' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "buying_price": "",
  "currency_id": "",
  "expense_id": "",
  "quantity": 0,
  "selling_price": "",
  "text": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expense_lines' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "buying_price": "",
  "currency_id": "",
  "expense_id": "",
  "quantity": 0,
  "selling_price": "",
  "text": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/expense_lines", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expense_lines"

payload = {
    "buying_price": "",
    "currency_id": "",
    "expense_id": "",
    "quantity": 0,
    "selling_price": "",
    "text": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expense_lines"

payload <- "{\n  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expense_lines")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\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/expense_lines') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"buying_price\": \"\",\n  \"currency_id\": \"\",\n  \"expense_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"text\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expense_lines";

    let payload = json!({
        "buying_price": "",
        "currency_id": "",
        "expense_id": "",
        "quantity": 0,
        "selling_price": "",
        "text": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expense_lines \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "buying_price": "",
  "currency_id": "",
  "expense_id": "",
  "quantity": 0,
  "selling_price": "",
  "text": ""
}'
echo '{
  "buying_price": "",
  "currency_id": "",
  "expense_id": "",
  "quantity": 0,
  "selling_price": "",
  "text": ""
}' |  \
  http POST {{baseUrl}}/expense_lines \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "buying_price": "",\n  "currency_id": "",\n  "expense_id": "",\n  "quantity": 0,\n  "selling_price": "",\n  "text": ""\n}' \
  --output-document \
  - {{baseUrl}}/expense_lines
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "buying_price": "",
  "currency_id": "",
  "expense_id": "",
  "quantity": 0,
  "selling_price": "",
  "text": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expense_lines")! 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 Delete expense line
{{baseUrl}}/expense_lines/:expense_line_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

expense_line_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expense_lines/:expense_line_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/expense_lines/:expense_line_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/expense_lines/:expense_line_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expense_lines/:expense_line_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expense_lines/:expense_line_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expense_lines/:expense_line_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/expense_lines/:expense_line_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/expense_lines/:expense_line_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expense_lines/:expense_line_id"))
    .header("x-auth-token", "{{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}}/expense_lines/:expense_line_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/expense_lines/:expense_line_id")
  .header("x-auth-token", "{{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}}/expense_lines/:expense_line_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/expense_lines/:expense_line_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expense_lines/:expense_line_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/expense_lines/:expense_line_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expense_lines/:expense_line_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expense_lines/:expense_line_id',
  headers: {
    'x-auth-token': '{{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}}/expense_lines/:expense_line_id',
  headers: {'x-auth-token': '{{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}}/expense_lines/:expense_line_id');

req.headers({
  'x-auth-token': '{{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}}/expense_lines/:expense_line_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expense_lines/:expense_line_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expense_lines/:expense_line_id"]
                                                       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}}/expense_lines/:expense_line_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expense_lines/:expense_line_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/expense_lines/:expense_line_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expense_lines/:expense_line_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expense_lines/:expense_line_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expense_lines/:expense_line_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expense_lines/:expense_line_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/expense_lines/:expense_line_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expense_lines/:expense_line_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expense_lines/:expense_line_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expense_lines/:expense_line_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/expense_lines/:expense_line_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expense_lines/:expense_line_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expense_lines/:expense_line_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/expense_lines/:expense_line_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/expense_lines/:expense_line_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expense_lines/:expense_line_id")! 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()
PUT Edit expense line
{{baseUrl}}/expense_lines/:expense_line_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

expense_line_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expense_lines/:expense_line_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/expense_lines/:expense_line_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/expense_lines/:expense_line_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expense_lines/:expense_line_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expense_lines/:expense_line_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expense_lines/:expense_line_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/expense_lines/:expense_line_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/expense_lines/:expense_line_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expense_lines/:expense_line_id"))
    .header("x-auth-token", "{{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}}/expense_lines/:expense_line_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/expense_lines/:expense_line_id")
  .header("x-auth-token", "{{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}}/expense_lines/:expense_line_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/expense_lines/:expense_line_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expense_lines/:expense_line_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/expense_lines/:expense_line_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expense_lines/:expense_line_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expense_lines/:expense_line_id',
  headers: {
    'x-auth-token': '{{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}}/expense_lines/:expense_line_id',
  headers: {'x-auth-token': '{{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}}/expense_lines/:expense_line_id');

req.headers({
  'x-auth-token': '{{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}}/expense_lines/:expense_line_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expense_lines/:expense_line_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expense_lines/:expense_line_id"]
                                                       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}}/expense_lines/:expense_line_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expense_lines/:expense_line_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/expense_lines/:expense_line_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expense_lines/:expense_line_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expense_lines/:expense_line_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expense_lines/:expense_line_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expense_lines/:expense_line_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/expense_lines/:expense_line_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expense_lines/:expense_line_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expense_lines/:expense_line_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expense_lines/:expense_line_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/expense_lines/:expense_line_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expense_lines/:expense_line_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expense_lines/:expense_line_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/expense_lines/:expense_line_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/expense_lines/:expense_line_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expense_lines/:expense_line_id")! 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()
GET Show expense line
{{baseUrl}}/expense_lines/:expense_line_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

expense_line_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expense_lines/:expense_line_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/expense_lines/:expense_line_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/expense_lines/:expense_line_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expense_lines/:expense_line_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expense_lines/:expense_line_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expense_lines/:expense_line_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/expense_lines/:expense_line_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/expense_lines/:expense_line_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expense_lines/:expense_line_id"))
    .header("x-auth-token", "{{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}}/expense_lines/:expense_line_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/expense_lines/:expense_line_id")
  .header("x-auth-token", "{{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}}/expense_lines/:expense_line_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/expense_lines/:expense_line_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expense_lines/:expense_line_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/expense_lines/:expense_line_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expense_lines/:expense_line_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expense_lines/:expense_line_id',
  headers: {
    'x-auth-token': '{{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}}/expense_lines/:expense_line_id',
  headers: {'x-auth-token': '{{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}}/expense_lines/:expense_line_id');

req.headers({
  'x-auth-token': '{{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}}/expense_lines/:expense_line_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expense_lines/:expense_line_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expense_lines/:expense_line_id"]
                                                       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}}/expense_lines/:expense_line_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expense_lines/:expense_line_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/expense_lines/:expense_line_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expense_lines/:expense_line_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expense_lines/:expense_line_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expense_lines/:expense_line_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expense_lines/:expense_line_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/expense_lines/:expense_line_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expense_lines/:expense_line_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expense_lines/:expense_line_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expense_lines/:expense_line_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/expense_lines/:expense_line_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expense_lines/:expense_line_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expense_lines/:expense_line_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/expense_lines/:expense_line_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/expense_lines/:expense_line_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expense_lines/:expense_line_id")! 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 Show list of expense lines
{{baseUrl}}/expense_lines
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expense_lines");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/expense_lines" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/expense_lines"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expense_lines"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expense_lines");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expense_lines"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/expense_lines HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/expense_lines")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expense_lines"))
    .header("x-auth-token", "{{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}}/expense_lines")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/expense_lines")
  .header("x-auth-token", "{{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}}/expense_lines');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/expense_lines',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expense_lines';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/expense_lines',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expense_lines")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expense_lines',
  headers: {
    'x-auth-token': '{{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}}/expense_lines',
  headers: {'x-auth-token': '{{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}}/expense_lines');

req.headers({
  'x-auth-token': '{{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}}/expense_lines',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expense_lines';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expense_lines"]
                                                       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}}/expense_lines" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expense_lines",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/expense_lines', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expense_lines');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expense_lines');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expense_lines' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expense_lines' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/expense_lines", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expense_lines"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expense_lines"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expense_lines")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/expense_lines') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expense_lines";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expense_lines \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/expense_lines \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/expense_lines
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expense_lines")! 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 line to expense (POST)
{{baseUrl}}/expenses
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "contact_id": "",
  "currency_id": "",
  "delivery_date": "",
  "description": "",
  "project_id": "",
  "reference": "",
  "short_text": "",
  "supplier_invoice_number": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expenses");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/expenses" {:headers {:x-auth-token "{{apiKey}}"}
                                                     :content-type :json
                                                     :form-params {:contact_id ""
                                                                   :currency_id ""
                                                                   :delivery_date ""
                                                                   :description ""
                                                                   :project_id ""
                                                                   :reference ""
                                                                   :short_text ""
                                                                   :supplier_invoice_number ""}})
require "http/client"

url = "{{baseUrl}}/expenses"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\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}}/expenses"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\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}}/expenses");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expenses"

	payload := strings.NewReader("{\n  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/expenses HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 179

{
  "contact_id": "",
  "currency_id": "",
  "delivery_date": "",
  "description": "",
  "project_id": "",
  "reference": "",
  "short_text": "",
  "supplier_invoice_number": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/expenses")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expenses"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\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  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/expenses")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/expenses")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  contact_id: '',
  currency_id: '',
  delivery_date: '',
  description: '',
  project_id: '',
  reference: '',
  short_text: '',
  supplier_invoice_number: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/expenses');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/expenses',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    contact_id: '',
    currency_id: '',
    delivery_date: '',
    description: '',
    project_id: '',
    reference: '',
    short_text: '',
    supplier_invoice_number: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expenses';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"contact_id":"","currency_id":"","delivery_date":"","description":"","project_id":"","reference":"","short_text":"","supplier_invoice_number":""}'
};

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}}/expenses',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "contact_id": "",\n  "currency_id": "",\n  "delivery_date": "",\n  "description": "",\n  "project_id": "",\n  "reference": "",\n  "short_text": "",\n  "supplier_invoice_number": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/expenses")
  .post(body)
  .addHeader("x-auth-token", "{{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/expenses',
  headers: {
    'x-auth-token': '{{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({
  contact_id: '',
  currency_id: '',
  delivery_date: '',
  description: '',
  project_id: '',
  reference: '',
  short_text: '',
  supplier_invoice_number: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/expenses',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    contact_id: '',
    currency_id: '',
    delivery_date: '',
    description: '',
    project_id: '',
    reference: '',
    short_text: '',
    supplier_invoice_number: ''
  },
  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}}/expenses');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  contact_id: '',
  currency_id: '',
  delivery_date: '',
  description: '',
  project_id: '',
  reference: '',
  short_text: '',
  supplier_invoice_number: ''
});

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}}/expenses',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    contact_id: '',
    currency_id: '',
    delivery_date: '',
    description: '',
    project_id: '',
    reference: '',
    short_text: '',
    supplier_invoice_number: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expenses';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"contact_id":"","currency_id":"","delivery_date":"","description":"","project_id":"","reference":"","short_text":"","supplier_invoice_number":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"contact_id": @"",
                              @"currency_id": @"",
                              @"delivery_date": @"",
                              @"description": @"",
                              @"project_id": @"",
                              @"reference": @"",
                              @"short_text": @"",
                              @"supplier_invoice_number": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expenses"]
                                                       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}}/expenses" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expenses",
  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([
    'contact_id' => '',
    'currency_id' => '',
    'delivery_date' => '',
    'description' => '',
    'project_id' => '',
    'reference' => '',
    'short_text' => '',
    'supplier_invoice_number' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/expenses', [
  'body' => '{
  "contact_id": "",
  "currency_id": "",
  "delivery_date": "",
  "description": "",
  "project_id": "",
  "reference": "",
  "short_text": "",
  "supplier_invoice_number": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expenses');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'contact_id' => '',
  'currency_id' => '',
  'delivery_date' => '',
  'description' => '',
  'project_id' => '',
  'reference' => '',
  'short_text' => '',
  'supplier_invoice_number' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'contact_id' => '',
  'currency_id' => '',
  'delivery_date' => '',
  'description' => '',
  'project_id' => '',
  'reference' => '',
  'short_text' => '',
  'supplier_invoice_number' => ''
]));
$request->setRequestUrl('{{baseUrl}}/expenses');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expenses' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "contact_id": "",
  "currency_id": "",
  "delivery_date": "",
  "description": "",
  "project_id": "",
  "reference": "",
  "short_text": "",
  "supplier_invoice_number": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expenses' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "contact_id": "",
  "currency_id": "",
  "delivery_date": "",
  "description": "",
  "project_id": "",
  "reference": "",
  "short_text": "",
  "supplier_invoice_number": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/expenses", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expenses"

payload = {
    "contact_id": "",
    "currency_id": "",
    "delivery_date": "",
    "description": "",
    "project_id": "",
    "reference": "",
    "short_text": "",
    "supplier_invoice_number": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expenses"

payload <- "{\n  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expenses")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\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/expenses') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"contact_id\": \"\",\n  \"currency_id\": \"\",\n  \"delivery_date\": \"\",\n  \"description\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"short_text\": \"\",\n  \"supplier_invoice_number\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expenses";

    let payload = json!({
        "contact_id": "",
        "currency_id": "",
        "delivery_date": "",
        "description": "",
        "project_id": "",
        "reference": "",
        "short_text": "",
        "supplier_invoice_number": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expenses \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "contact_id": "",
  "currency_id": "",
  "delivery_date": "",
  "description": "",
  "project_id": "",
  "reference": "",
  "short_text": "",
  "supplier_invoice_number": ""
}'
echo '{
  "contact_id": "",
  "currency_id": "",
  "delivery_date": "",
  "description": "",
  "project_id": "",
  "reference": "",
  "short_text": "",
  "supplier_invoice_number": ""
}' |  \
  http POST {{baseUrl}}/expenses \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "contact_id": "",\n  "currency_id": "",\n  "delivery_date": "",\n  "description": "",\n  "project_id": "",\n  "reference": "",\n  "short_text": "",\n  "supplier_invoice_number": ""\n}' \
  --output-document \
  - {{baseUrl}}/expenses
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "contact_id": "",
  "currency_id": "",
  "delivery_date": "",
  "description": "",
  "project_id": "",
  "reference": "",
  "short_text": "",
  "supplier_invoice_number": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expenses")! 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 Bulk delete expenses (DELETE)
{{baseUrl}}/expenses/sendEmails
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expenses/sendEmails");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/expenses/sendEmails" {:headers {:x-auth-token "{{apiKey}}"}
                                                                  :content-type :json
                                                                  :form-params {:id []}})
require "http/client"

url = "{{baseUrl}}/expenses/sendEmails"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": []\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}}/expenses/sendEmails"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id\": []\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}}/expenses/sendEmails");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expenses/sendEmails"

	payload := strings.NewReader("{\n  \"id\": []\n}")

	req, _ := http.NewRequest("DELETE", url, payload)

	req.Header.Add("x-auth-token", "{{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/expenses/sendEmails HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/expenses/sendEmails")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expenses/sendEmails"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"id\": []\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\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/expenses/sendEmails")
  .delete(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/expenses/sendEmails")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/expenses/sendEmails');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/expenses/sendEmails',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expenses/sendEmails';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/expenses/sendEmails',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/expenses/sendEmails")
  .delete(body)
  .addHeader("x-auth-token", "{{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/expenses/sendEmails',
  headers: {
    'x-auth-token': '{{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: []}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/expenses/sendEmails',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {id: []},
  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}}/expenses/sendEmails');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: []
});

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}}/expenses/sendEmails',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expenses/sendEmails';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expenses/sendEmails"]
                                                       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}}/expenses/sendEmails" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": []\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expenses/sendEmails",
  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([
    'id' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/expenses/sendEmails', [
  'body' => '{
  "id": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expenses/sendEmails');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/expenses/sendEmails');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expenses/sendEmails' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expenses/sendEmails' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": []\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("DELETE", "/baseUrl/expenses/sendEmails", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expenses/sendEmails"

payload = { "id": [] }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expenses/sendEmails"

payload <- "{\n  \"id\": []\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expenses/sendEmails")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/expenses/sendEmails') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"id\": []\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}}/expenses/sendEmails";

    let payload = json!({"id": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expenses/sendEmails \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http DELETE {{baseUrl}}/expenses/sendEmails \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/expenses/sendEmails
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expenses/sendEmails")! 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 Bulk delete expenses
{{baseUrl}}/expenses/bulkDelete
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expenses/bulkDelete");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/expenses/bulkDelete" {:headers {:x-auth-token "{{apiKey}}"}
                                                                  :content-type :json
                                                                  :form-params {:id []}})
require "http/client"

url = "{{baseUrl}}/expenses/bulkDelete"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": []\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}}/expenses/bulkDelete"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id\": []\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}}/expenses/bulkDelete");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expenses/bulkDelete"

	payload := strings.NewReader("{\n  \"id\": []\n}")

	req, _ := http.NewRequest("DELETE", url, payload)

	req.Header.Add("x-auth-token", "{{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/expenses/bulkDelete HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/expenses/bulkDelete")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expenses/bulkDelete"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"id\": []\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\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/expenses/bulkDelete")
  .delete(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/expenses/bulkDelete")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/expenses/bulkDelete');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/expenses/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expenses/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/expenses/bulkDelete',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/expenses/bulkDelete")
  .delete(body)
  .addHeader("x-auth-token", "{{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/expenses/bulkDelete',
  headers: {
    'x-auth-token': '{{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: []}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/expenses/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {id: []},
  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}}/expenses/bulkDelete');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: []
});

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}}/expenses/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expenses/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expenses/bulkDelete"]
                                                       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}}/expenses/bulkDelete" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": []\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expenses/bulkDelete",
  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([
    'id' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/expenses/bulkDelete', [
  'body' => '{
  "id": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expenses/bulkDelete');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/expenses/bulkDelete');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expenses/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expenses/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": []\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("DELETE", "/baseUrl/expenses/bulkDelete", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expenses/bulkDelete"

payload = { "id": [] }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expenses/bulkDelete"

payload <- "{\n  \"id\": []\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expenses/bulkDelete")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/expenses/bulkDelete') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"id\": []\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}}/expenses/bulkDelete";

    let payload = json!({"id": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expenses/bulkDelete \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http DELETE {{baseUrl}}/expenses/bulkDelete \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/expenses/bulkDelete
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expenses/bulkDelete")! 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 expense
{{baseUrl}}/expenses/:expense_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

expense_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expenses/:expense_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/expenses/:expense_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/expenses/:expense_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expenses/:expense_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expenses/:expense_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expenses/:expense_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/expenses/:expense_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/expenses/:expense_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expenses/:expense_id"))
    .header("x-auth-token", "{{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}}/expenses/:expense_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/expenses/:expense_id")
  .header("x-auth-token", "{{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}}/expenses/:expense_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/expenses/:expense_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expenses/:expense_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/expenses/:expense_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expenses/:expense_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expenses/:expense_id',
  headers: {
    'x-auth-token': '{{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}}/expenses/:expense_id',
  headers: {'x-auth-token': '{{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}}/expenses/:expense_id');

req.headers({
  'x-auth-token': '{{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}}/expenses/:expense_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expenses/:expense_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expenses/:expense_id"]
                                                       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}}/expenses/:expense_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expenses/:expense_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/expenses/:expense_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expenses/:expense_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expenses/:expense_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expenses/:expense_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expenses/:expense_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/expenses/:expense_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expenses/:expense_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expenses/:expense_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expenses/:expense_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/expenses/:expense_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expenses/:expense_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expenses/:expense_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/expenses/:expense_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/expenses/:expense_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expenses/:expense_id")! 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()
PUT Edit expense
{{baseUrl}}/expenses/:expense_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

expense_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expenses/:expense_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/expenses/:expense_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/expenses/:expense_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expenses/:expense_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expenses/:expense_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expenses/:expense_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/expenses/:expense_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/expenses/:expense_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expenses/:expense_id"))
    .header("x-auth-token", "{{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}}/expenses/:expense_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/expenses/:expense_id")
  .header("x-auth-token", "{{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}}/expenses/:expense_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/expenses/:expense_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expenses/:expense_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/expenses/:expense_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expenses/:expense_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expenses/:expense_id',
  headers: {
    'x-auth-token': '{{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}}/expenses/:expense_id',
  headers: {'x-auth-token': '{{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}}/expenses/:expense_id');

req.headers({
  'x-auth-token': '{{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}}/expenses/:expense_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expenses/:expense_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expenses/:expense_id"]
                                                       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}}/expenses/:expense_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expenses/:expense_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/expenses/:expense_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expenses/:expense_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expenses/:expense_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expenses/:expense_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expenses/:expense_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/expenses/:expense_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expenses/:expense_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expenses/:expense_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expenses/:expense_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/expenses/:expense_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expenses/:expense_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expenses/:expense_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/expenses/:expense_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/expenses/:expense_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expenses/:expense_id")! 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()
GET Show expense
{{baseUrl}}/expenses/:expense_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

expense_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expenses/:expense_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/expenses/:expense_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/expenses/:expense_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expenses/:expense_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expenses/:expense_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expenses/:expense_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/expenses/:expense_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/expenses/:expense_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expenses/:expense_id"))
    .header("x-auth-token", "{{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}}/expenses/:expense_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/expenses/:expense_id")
  .header("x-auth-token", "{{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}}/expenses/:expense_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/expenses/:expense_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expenses/:expense_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/expenses/:expense_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expenses/:expense_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expenses/:expense_id',
  headers: {
    'x-auth-token': '{{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}}/expenses/:expense_id',
  headers: {'x-auth-token': '{{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}}/expenses/:expense_id');

req.headers({
  'x-auth-token': '{{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}}/expenses/:expense_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expenses/:expense_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expenses/:expense_id"]
                                                       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}}/expenses/:expense_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expenses/:expense_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/expenses/:expense_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expenses/:expense_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expenses/:expense_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expenses/:expense_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expenses/:expense_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/expenses/:expense_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expenses/:expense_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expenses/:expense_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expenses/:expense_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/expenses/:expense_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expenses/:expense_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expenses/:expense_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/expenses/:expense_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/expenses/:expense_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expenses/:expense_id")! 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 Show highest Expense amount(`total_selling_price`)
{{baseUrl}}/expenses/highest_amount
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

gt_created
lt_created
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expenses/highest_amount?gt_created=<_created=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/expenses/highest_amount" {:headers {:x-auth-token "{{apiKey}}"}
                                                                   :query-params {:gt_created ""
                                                                                  :lt_created ""}})
require "http/client"

url = "{{baseUrl}}/expenses/highest_amount?gt_created=<_created="
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expenses/highest_amount?gt_created=<_created="),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expenses/highest_amount?gt_created=<_created=");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expenses/highest_amount?gt_created=<_created="

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/expenses/highest_amount?gt_created=<_created= HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/expenses/highest_amount?gt_created=<_created=")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expenses/highest_amount?gt_created=<_created="))
    .header("x-auth-token", "{{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}}/expenses/highest_amount?gt_created=<_created=")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/expenses/highest_amount?gt_created=<_created=")
  .header("x-auth-token", "{{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}}/expenses/highest_amount?gt_created=<_created=');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/expenses/highest_amount',
  params: {gt_created: '', lt_created: ''},
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expenses/highest_amount?gt_created=<_created=';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/expenses/highest_amount?gt_created=<_created=',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expenses/highest_amount?gt_created=<_created=")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expenses/highest_amount?gt_created=<_created=',
  headers: {
    'x-auth-token': '{{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}}/expenses/highest_amount',
  qs: {gt_created: '', lt_created: ''},
  headers: {'x-auth-token': '{{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}}/expenses/highest_amount');

req.query({
  gt_created: '',
  lt_created: ''
});

req.headers({
  'x-auth-token': '{{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}}/expenses/highest_amount',
  params: {gt_created: '', lt_created: ''},
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expenses/highest_amount?gt_created=<_created=';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expenses/highest_amount?gt_created=<_created="]
                                                       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}}/expenses/highest_amount?gt_created=<_created=" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expenses/highest_amount?gt_created=<_created=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/expenses/highest_amount?gt_created=<_created=', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expenses/highest_amount');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'gt_created' => '',
  'lt_created' => ''
]);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expenses/highest_amount');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'gt_created' => '',
  'lt_created' => ''
]));

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expenses/highest_amount?gt_created=<_created=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expenses/highest_amount?gt_created=<_created=' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/expenses/highest_amount?gt_created=<_created=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expenses/highest_amount"

querystring = {"gt_created":"","lt_created":""}

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expenses/highest_amount"

queryString <- list(
  gt_created = "",
  lt_created = ""
)

response <- VERB("GET", url, query = queryString, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expenses/highest_amount?gt_created=<_created=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/expenses/highest_amount') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.params['gt_created'] = ''
  req.params['lt_created'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expenses/highest_amount";

    let querystring = [
        ("gt_created", ""),
        ("lt_created", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expenses/highest_amount?gt_created=<_created=' \
  --header 'x-auth-token: {{apiKey}}'
http GET '{{baseUrl}}/expenses/highest_amount?gt_created=<_created=' \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/expenses/highest_amount?gt_created=<_created='
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expenses/highest_amount?gt_created=<_created=")! 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 Show list of expenses
{{baseUrl}}/expenses
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/expenses");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/expenses" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/expenses"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/expenses"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/expenses");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/expenses"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/expenses HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/expenses")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/expenses"))
    .header("x-auth-token", "{{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}}/expenses")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/expenses")
  .header("x-auth-token", "{{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}}/expenses');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/expenses',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/expenses';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/expenses',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/expenses")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/expenses',
  headers: {
    'x-auth-token': '{{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}}/expenses',
  headers: {'x-auth-token': '{{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}}/expenses');

req.headers({
  'x-auth-token': '{{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}}/expenses',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/expenses';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/expenses"]
                                                       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}}/expenses" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/expenses",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/expenses', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/expenses');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/expenses');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/expenses' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/expenses' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/expenses", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/expenses"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/expenses"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/expenses")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/expenses') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/expenses";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/expenses \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/expenses \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/expenses
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/expenses")! 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 expenses sales price
{{baseUrl}}/financial_statistics/expensesSalesPrice
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/financial_statistics/expensesSalesPrice");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/financial_statistics/expensesSalesPrice" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/financial_statistics/expensesSalesPrice"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/financial_statistics/expensesSalesPrice"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/financial_statistics/expensesSalesPrice");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/financial_statistics/expensesSalesPrice"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/financial_statistics/expensesSalesPrice HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/financial_statistics/expensesSalesPrice")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/financial_statistics/expensesSalesPrice"))
    .header("x-auth-token", "{{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}}/financial_statistics/expensesSalesPrice")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/financial_statistics/expensesSalesPrice")
  .header("x-auth-token", "{{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}}/financial_statistics/expensesSalesPrice');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/financial_statistics/expensesSalesPrice',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/financial_statistics/expensesSalesPrice';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/financial_statistics/expensesSalesPrice',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/financial_statistics/expensesSalesPrice")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/financial_statistics/expensesSalesPrice',
  headers: {
    'x-auth-token': '{{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}}/financial_statistics/expensesSalesPrice',
  headers: {'x-auth-token': '{{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}}/financial_statistics/expensesSalesPrice');

req.headers({
  'x-auth-token': '{{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}}/financial_statistics/expensesSalesPrice',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/financial_statistics/expensesSalesPrice';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/financial_statistics/expensesSalesPrice"]
                                                       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}}/financial_statistics/expensesSalesPrice" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/financial_statistics/expensesSalesPrice",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/financial_statistics/expensesSalesPrice', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/financial_statistics/expensesSalesPrice');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/financial_statistics/expensesSalesPrice');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/financial_statistics/expensesSalesPrice' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/financial_statistics/expensesSalesPrice' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/financial_statistics/expensesSalesPrice", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/financial_statistics/expensesSalesPrice"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/financial_statistics/expensesSalesPrice"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/financial_statistics/expensesSalesPrice")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/financial_statistics/expensesSalesPrice') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/financial_statistics/expensesSalesPrice";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/financial_statistics/expensesSalesPrice \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/financial_statistics/expensesSalesPrice \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/financial_statistics/expensesSalesPrice
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/financial_statistics/expensesSalesPrice")! 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 general statistics
{{baseUrl}}/financial_statistics
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/financial_statistics");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/financial_statistics" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/financial_statistics"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/financial_statistics"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/financial_statistics");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/financial_statistics"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/financial_statistics HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/financial_statistics")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/financial_statistics"))
    .header("x-auth-token", "{{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}}/financial_statistics")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/financial_statistics")
  .header("x-auth-token", "{{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}}/financial_statistics');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/financial_statistics',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/financial_statistics';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/financial_statistics',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/financial_statistics")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/financial_statistics',
  headers: {
    'x-auth-token': '{{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}}/financial_statistics',
  headers: {'x-auth-token': '{{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}}/financial_statistics');

req.headers({
  'x-auth-token': '{{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}}/financial_statistics',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/financial_statistics';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/financial_statistics"]
                                                       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}}/financial_statistics" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/financial_statistics",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/financial_statistics', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/financial_statistics');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/financial_statistics');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/financial_statistics' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/financial_statistics' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/financial_statistics", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/financial_statistics"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/financial_statistics"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/financial_statistics")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/financial_statistics') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/financial_statistics";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/financial_statistics \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/financial_statistics \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/financial_statistics
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/financial_statistics")! 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

{
  "data": {
    "invoicedWorkingHours": "00:00",
    "notInvoicedWorkingHours": "00:00"
  }
}
GET Get invoiced amount
{{baseUrl}}/financial_statistics/invoicedAmount
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/financial_statistics/invoicedAmount");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/financial_statistics/invoicedAmount" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/financial_statistics/invoicedAmount"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/financial_statistics/invoicedAmount"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/financial_statistics/invoicedAmount");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/financial_statistics/invoicedAmount"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/financial_statistics/invoicedAmount HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/financial_statistics/invoicedAmount")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/financial_statistics/invoicedAmount"))
    .header("x-auth-token", "{{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}}/financial_statistics/invoicedAmount")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/financial_statistics/invoicedAmount")
  .header("x-auth-token", "{{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}}/financial_statistics/invoicedAmount');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/financial_statistics/invoicedAmount',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/financial_statistics/invoicedAmount';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/financial_statistics/invoicedAmount',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/financial_statistics/invoicedAmount")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/financial_statistics/invoicedAmount',
  headers: {
    'x-auth-token': '{{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}}/financial_statistics/invoicedAmount',
  headers: {'x-auth-token': '{{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}}/financial_statistics/invoicedAmount');

req.headers({
  'x-auth-token': '{{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}}/financial_statistics/invoicedAmount',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/financial_statistics/invoicedAmount';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/financial_statistics/invoicedAmount"]
                                                       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}}/financial_statistics/invoicedAmount" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/financial_statistics/invoicedAmount",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/financial_statistics/invoicedAmount', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/financial_statistics/invoicedAmount');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/financial_statistics/invoicedAmount');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/financial_statistics/invoicedAmount' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/financial_statistics/invoicedAmount' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/financial_statistics/invoicedAmount", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/financial_statistics/invoicedAmount"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/financial_statistics/invoicedAmount"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/financial_statistics/invoicedAmount")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/financial_statistics/invoicedAmount') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/financial_statistics/invoicedAmount";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/financial_statistics/invoicedAmount \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/financial_statistics/invoicedAmount \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/financial_statistics/invoicedAmount
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/financial_statistics/invoicedAmount")! 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 margin
{{baseUrl}}/financial_statistics/margin
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/financial_statistics/margin");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/financial_statistics/margin" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/financial_statistics/margin"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/financial_statistics/margin"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/financial_statistics/margin");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/financial_statistics/margin"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/financial_statistics/margin HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/financial_statistics/margin")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/financial_statistics/margin"))
    .header("x-auth-token", "{{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}}/financial_statistics/margin")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/financial_statistics/margin")
  .header("x-auth-token", "{{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}}/financial_statistics/margin');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/financial_statistics/margin',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/financial_statistics/margin';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/financial_statistics/margin',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/financial_statistics/margin")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/financial_statistics/margin',
  headers: {
    'x-auth-token': '{{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}}/financial_statistics/margin',
  headers: {'x-auth-token': '{{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}}/financial_statistics/margin');

req.headers({
  'x-auth-token': '{{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}}/financial_statistics/margin',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/financial_statistics/margin';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/financial_statistics/margin"]
                                                       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}}/financial_statistics/margin" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/financial_statistics/margin",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/financial_statistics/margin', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/financial_statistics/margin');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/financial_statistics/margin');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/financial_statistics/margin' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/financial_statistics/margin' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/financial_statistics/margin", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/financial_statistics/margin"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/financial_statistics/margin"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/financial_statistics/margin")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/financial_statistics/margin') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/financial_statistics/margin";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/financial_statistics/margin \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/financial_statistics/margin \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/financial_statistics/margin
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/financial_statistics/margin")! 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 products cost price
{{baseUrl}}/financial_statistics/productsCostPrice
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/financial_statistics/productsCostPrice");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/financial_statistics/productsCostPrice" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/financial_statistics/productsCostPrice"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/financial_statistics/productsCostPrice"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/financial_statistics/productsCostPrice");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/financial_statistics/productsCostPrice"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/financial_statistics/productsCostPrice HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/financial_statistics/productsCostPrice")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/financial_statistics/productsCostPrice"))
    .header("x-auth-token", "{{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}}/financial_statistics/productsCostPrice")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/financial_statistics/productsCostPrice")
  .header("x-auth-token", "{{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}}/financial_statistics/productsCostPrice');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/financial_statistics/productsCostPrice',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/financial_statistics/productsCostPrice';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/financial_statistics/productsCostPrice',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/financial_statistics/productsCostPrice")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/financial_statistics/productsCostPrice',
  headers: {
    'x-auth-token': '{{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}}/financial_statistics/productsCostPrice',
  headers: {'x-auth-token': '{{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}}/financial_statistics/productsCostPrice');

req.headers({
  'x-auth-token': '{{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}}/financial_statistics/productsCostPrice',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/financial_statistics/productsCostPrice';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/financial_statistics/productsCostPrice"]
                                                       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}}/financial_statistics/productsCostPrice" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/financial_statistics/productsCostPrice",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/financial_statistics/productsCostPrice', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/financial_statistics/productsCostPrice');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/financial_statistics/productsCostPrice');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/financial_statistics/productsCostPrice' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/financial_statistics/productsCostPrice' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/financial_statistics/productsCostPrice", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/financial_statistics/productsCostPrice"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/financial_statistics/productsCostPrice"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/financial_statistics/productsCostPrice")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/financial_statistics/productsCostPrice') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/financial_statistics/productsCostPrice";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/financial_statistics/productsCostPrice \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/financial_statistics/productsCostPrice \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/financial_statistics/productsCostPrice
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/financial_statistics/productsCostPrice")! 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 products material rentals cost price
{{baseUrl}}/financial_statistics/materialRentalsCostPrice
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/financial_statistics/materialRentalsCostPrice");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/financial_statistics/materialRentalsCostPrice" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/financial_statistics/materialRentalsCostPrice"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/financial_statistics/materialRentalsCostPrice"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/financial_statistics/materialRentalsCostPrice");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/financial_statistics/materialRentalsCostPrice"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/financial_statistics/materialRentalsCostPrice HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/financial_statistics/materialRentalsCostPrice")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/financial_statistics/materialRentalsCostPrice"))
    .header("x-auth-token", "{{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}}/financial_statistics/materialRentalsCostPrice")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/financial_statistics/materialRentalsCostPrice")
  .header("x-auth-token", "{{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}}/financial_statistics/materialRentalsCostPrice');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/financial_statistics/materialRentalsCostPrice',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/financial_statistics/materialRentalsCostPrice';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/financial_statistics/materialRentalsCostPrice',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/financial_statistics/materialRentalsCostPrice")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/financial_statistics/materialRentalsCostPrice',
  headers: {
    'x-auth-token': '{{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}}/financial_statistics/materialRentalsCostPrice',
  headers: {'x-auth-token': '{{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}}/financial_statistics/materialRentalsCostPrice');

req.headers({
  'x-auth-token': '{{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}}/financial_statistics/materialRentalsCostPrice',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/financial_statistics/materialRentalsCostPrice';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/financial_statistics/materialRentalsCostPrice"]
                                                       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}}/financial_statistics/materialRentalsCostPrice" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/financial_statistics/materialRentalsCostPrice",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/financial_statistics/materialRentalsCostPrice', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/financial_statistics/materialRentalsCostPrice');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/financial_statistics/materialRentalsCostPrice');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/financial_statistics/materialRentalsCostPrice' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/financial_statistics/materialRentalsCostPrice' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/financial_statistics/materialRentalsCostPrice", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/financial_statistics/materialRentalsCostPrice"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/financial_statistics/materialRentalsCostPrice"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/financial_statistics/materialRentalsCostPrice")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/financial_statistics/materialRentalsCostPrice') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/financial_statistics/materialRentalsCostPrice";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/financial_statistics/materialRentalsCostPrice \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/financial_statistics/materialRentalsCostPrice \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/financial_statistics/materialRentalsCostPrice
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/financial_statistics/materialRentalsCostPrice")! 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 statistics overview
{{baseUrl}}/financial_statistics/overview
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/financial_statistics/overview");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/financial_statistics/overview" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/financial_statistics/overview"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/financial_statistics/overview"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/financial_statistics/overview");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/financial_statistics/overview"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/financial_statistics/overview HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/financial_statistics/overview")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/financial_statistics/overview"))
    .header("x-auth-token", "{{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}}/financial_statistics/overview")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/financial_statistics/overview")
  .header("x-auth-token", "{{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}}/financial_statistics/overview');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/financial_statistics/overview',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/financial_statistics/overview';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/financial_statistics/overview',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/financial_statistics/overview")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/financial_statistics/overview',
  headers: {
    'x-auth-token': '{{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}}/financial_statistics/overview',
  headers: {'x-auth-token': '{{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}}/financial_statistics/overview');

req.headers({
  'x-auth-token': '{{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}}/financial_statistics/overview',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/financial_statistics/overview';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/financial_statistics/overview"]
                                                       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}}/financial_statistics/overview" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/financial_statistics/overview",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/financial_statistics/overview', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/financial_statistics/overview');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/financial_statistics/overview');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/financial_statistics/overview' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/financial_statistics/overview' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/financial_statistics/overview", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/financial_statistics/overview"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/financial_statistics/overview"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/financial_statistics/overview")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/financial_statistics/overview') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/financial_statistics/overview";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/financial_statistics/overview \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/financial_statistics/overview \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/financial_statistics/overview
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/financial_statistics/overview")! 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

{
  "data": {
    "totalWorkingHours": "00:00"
  }
}
GET Get Total working hours grouped by time entry type
{{baseUrl}}/financial_statistics/workingHours
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/financial_statistics/workingHours");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/financial_statistics/workingHours" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/financial_statistics/workingHours"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/financial_statistics/workingHours"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/financial_statistics/workingHours");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/financial_statistics/workingHours"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/financial_statistics/workingHours HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/financial_statistics/workingHours")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/financial_statistics/workingHours"))
    .header("x-auth-token", "{{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}}/financial_statistics/workingHours")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/financial_statistics/workingHours")
  .header("x-auth-token", "{{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}}/financial_statistics/workingHours');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/financial_statistics/workingHours',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/financial_statistics/workingHours';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/financial_statistics/workingHours',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/financial_statistics/workingHours")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/financial_statistics/workingHours',
  headers: {
    'x-auth-token': '{{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}}/financial_statistics/workingHours',
  headers: {'x-auth-token': '{{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}}/financial_statistics/workingHours');

req.headers({
  'x-auth-token': '{{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}}/financial_statistics/workingHours',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/financial_statistics/workingHours';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/financial_statistics/workingHours"]
                                                       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}}/financial_statistics/workingHours" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/financial_statistics/workingHours",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/financial_statistics/workingHours', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/financial_statistics/workingHours');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/financial_statistics/workingHours');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/financial_statistics/workingHours' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/financial_statistics/workingHours' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/financial_statistics/workingHours", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/financial_statistics/workingHours"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/financial_statistics/workingHours"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/financial_statistics/workingHours")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/financial_statistics/workingHours') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/financial_statistics/workingHours";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/financial_statistics/workingHours \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/financial_statistics/workingHours \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/financial_statistics/workingHours
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/financial_statistics/workingHours")! 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 a new field to a `Form`
{{baseUrl}}/form_fields
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "comment": "",
  "content_value": "",
  "file_id": "",
  "form_field_type_id": "",
  "form_id": "",
  "form_template_field_id": "",
  "placement": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/form_fields");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/form_fields" {:headers {:x-auth-token "{{apiKey}}"}
                                                        :content-type :json
                                                        :form-params {:comment ""
                                                                      :content_value ""
                                                                      :file_id ""
                                                                      :form_field_type_id ""
                                                                      :form_id ""
                                                                      :form_template_field_id ""
                                                                      :placement 0}})
require "http/client"

url = "{{baseUrl}}/form_fields"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\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}}/form_fields"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\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}}/form_fields");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/form_fields"

	payload := strings.NewReader("{\n  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/form_fields HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 154

{
  "comment": "",
  "content_value": "",
  "file_id": "",
  "form_field_type_id": "",
  "form_id": "",
  "form_template_field_id": "",
  "placement": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/form_fields")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/form_fields"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\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  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/form_fields")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/form_fields")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\n}")
  .asString();
const data = JSON.stringify({
  comment: '',
  content_value: '',
  file_id: '',
  form_field_type_id: '',
  form_id: '',
  form_template_field_id: '',
  placement: 0
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/form_fields');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/form_fields',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    comment: '',
    content_value: '',
    file_id: '',
    form_field_type_id: '',
    form_id: '',
    form_template_field_id: '',
    placement: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/form_fields';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"comment":"","content_value":"","file_id":"","form_field_type_id":"","form_id":"","form_template_field_id":"","placement":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}}/form_fields',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "comment": "",\n  "content_value": "",\n  "file_id": "",\n  "form_field_type_id": "",\n  "form_id": "",\n  "form_template_field_id": "",\n  "placement": 0\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/form_fields")
  .post(body)
  .addHeader("x-auth-token", "{{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/form_fields',
  headers: {
    'x-auth-token': '{{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({
  comment: '',
  content_value: '',
  file_id: '',
  form_field_type_id: '',
  form_id: '',
  form_template_field_id: '',
  placement: 0
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/form_fields',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    comment: '',
    content_value: '',
    file_id: '',
    form_field_type_id: '',
    form_id: '',
    form_template_field_id: '',
    placement: 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('POST', '{{baseUrl}}/form_fields');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  comment: '',
  content_value: '',
  file_id: '',
  form_field_type_id: '',
  form_id: '',
  form_template_field_id: '',
  placement: 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: 'POST',
  url: '{{baseUrl}}/form_fields',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    comment: '',
    content_value: '',
    file_id: '',
    form_field_type_id: '',
    form_id: '',
    form_template_field_id: '',
    placement: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/form_fields';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"comment":"","content_value":"","file_id":"","form_field_type_id":"","form_id":"","form_template_field_id":"","placement":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"comment": @"",
                              @"content_value": @"",
                              @"file_id": @"",
                              @"form_field_type_id": @"",
                              @"form_id": @"",
                              @"form_template_field_id": @"",
                              @"placement": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/form_fields"]
                                                       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}}/form_fields" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/form_fields",
  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([
    'comment' => '',
    'content_value' => '',
    'file_id' => '',
    'form_field_type_id' => '',
    'form_id' => '',
    'form_template_field_id' => '',
    'placement' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/form_fields', [
  'body' => '{
  "comment": "",
  "content_value": "",
  "file_id": "",
  "form_field_type_id": "",
  "form_id": "",
  "form_template_field_id": "",
  "placement": 0
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/form_fields');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'comment' => '',
  'content_value' => '',
  'file_id' => '',
  'form_field_type_id' => '',
  'form_id' => '',
  'form_template_field_id' => '',
  'placement' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'comment' => '',
  'content_value' => '',
  'file_id' => '',
  'form_field_type_id' => '',
  'form_id' => '',
  'form_template_field_id' => '',
  'placement' => 0
]));
$request->setRequestUrl('{{baseUrl}}/form_fields');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/form_fields' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "comment": "",
  "content_value": "",
  "file_id": "",
  "form_field_type_id": "",
  "form_id": "",
  "form_template_field_id": "",
  "placement": 0
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/form_fields' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "comment": "",
  "content_value": "",
  "file_id": "",
  "form_field_type_id": "",
  "form_id": "",
  "form_template_field_id": "",
  "placement": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/form_fields", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/form_fields"

payload = {
    "comment": "",
    "content_value": "",
    "file_id": "",
    "form_field_type_id": "",
    "form_id": "",
    "form_template_field_id": "",
    "placement": 0
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/form_fields"

payload <- "{\n  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/form_fields")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\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/form_fields') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"comment\": \"\",\n  \"content_value\": \"\",\n  \"file_id\": \"\",\n  \"form_field_type_id\": \"\",\n  \"form_id\": \"\",\n  \"form_template_field_id\": \"\",\n  \"placement\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/form_fields";

    let payload = json!({
        "comment": "",
        "content_value": "",
        "file_id": "",
        "form_field_type_id": "",
        "form_id": "",
        "form_template_field_id": "",
        "placement": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/form_fields \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "comment": "",
  "content_value": "",
  "file_id": "",
  "form_field_type_id": "",
  "form_id": "",
  "form_template_field_id": "",
  "placement": 0
}'
echo '{
  "comment": "",
  "content_value": "",
  "file_id": "",
  "form_field_type_id": "",
  "form_id": "",
  "form_template_field_id": "",
  "placement": 0
}' |  \
  http POST {{baseUrl}}/form_fields \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "comment": "",\n  "content_value": "",\n  "file_id": "",\n  "form_field_type_id": "",\n  "form_id": "",\n  "form_template_field_id": "",\n  "placement": 0\n}' \
  --output-document \
  - {{baseUrl}}/form_fields
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "comment": "",
  "content_value": "",
  "file_id": "",
  "form_field_type_id": "",
  "form_id": "",
  "form_template_field_id": "",
  "placement": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/form_fields")! 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 details about single `FormField` (GET)
{{baseUrl}}/form_fields/:form_field_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

form_field_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/form_fields/:form_field_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/form_fields/:form_field_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/form_fields/:form_field_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/form_fields/:form_field_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/form_fields/:form_field_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/form_fields/:form_field_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/form_fields/:form_field_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/form_fields/:form_field_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/form_fields/:form_field_id"))
    .header("x-auth-token", "{{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}}/form_fields/:form_field_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/form_fields/:form_field_id")
  .header("x-auth-token", "{{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}}/form_fields/:form_field_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/form_fields/:form_field_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/form_fields/:form_field_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/form_fields/:form_field_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/form_fields/:form_field_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/form_fields/:form_field_id',
  headers: {
    'x-auth-token': '{{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}}/form_fields/:form_field_id',
  headers: {'x-auth-token': '{{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}}/form_fields/:form_field_id');

req.headers({
  'x-auth-token': '{{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}}/form_fields/:form_field_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/form_fields/:form_field_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/form_fields/:form_field_id"]
                                                       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}}/form_fields/:form_field_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/form_fields/:form_field_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/form_fields/:form_field_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/form_fields/:form_field_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/form_fields/:form_field_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/form_fields/:form_field_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/form_fields/:form_field_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/form_fields/:form_field_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/form_fields/:form_field_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/form_fields/:form_field_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/form_fields/:form_field_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/form_fields/:form_field_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/form_fields/:form_field_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/form_fields/:form_field_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/form_fields/:form_field_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/form_fields/:form_field_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/form_fields/:form_field_id")! 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 details about single `FormField`
{{baseUrl}}/form_field_types/:form_field_type_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

form_field_type_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/form_field_types/:form_field_type_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/form_field_types/:form_field_type_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/form_field_types/:form_field_type_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/form_field_types/:form_field_type_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/form_field_types/:form_field_type_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/form_field_types/:form_field_type_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/form_field_types/:form_field_type_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/form_field_types/:form_field_type_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/form_field_types/:form_field_type_id"))
    .header("x-auth-token", "{{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}}/form_field_types/:form_field_type_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/form_field_types/:form_field_type_id")
  .header("x-auth-token", "{{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}}/form_field_types/:form_field_type_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/form_field_types/:form_field_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/form_field_types/:form_field_type_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/form_field_types/:form_field_type_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/form_field_types/:form_field_type_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/form_field_types/:form_field_type_id',
  headers: {
    'x-auth-token': '{{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}}/form_field_types/:form_field_type_id',
  headers: {'x-auth-token': '{{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}}/form_field_types/:form_field_type_id');

req.headers({
  'x-auth-token': '{{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}}/form_field_types/:form_field_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/form_field_types/:form_field_type_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/form_field_types/:form_field_type_id"]
                                                       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}}/form_field_types/:form_field_type_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/form_field_types/:form_field_type_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/form_field_types/:form_field_type_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/form_field_types/:form_field_type_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/form_field_types/:form_field_type_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/form_field_types/:form_field_type_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/form_field_types/:form_field_type_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/form_field_types/:form_field_type_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/form_field_types/:form_field_type_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/form_field_types/:form_field_type_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/form_field_types/:form_field_type_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/form_field_types/:form_field_type_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/form_field_types/:form_field_type_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/form_field_types/:form_field_type_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/form_field_types/:form_field_type_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/form_field_types/:form_field_type_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/form_field_types/:form_field_type_id")! 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 list of form field types
{{baseUrl}}/form_field_types
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/form_field_types");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/form_field_types" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/form_field_types"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/form_field_types"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/form_field_types");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/form_field_types"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/form_field_types HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/form_field_types")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/form_field_types"))
    .header("x-auth-token", "{{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}}/form_field_types")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/form_field_types")
  .header("x-auth-token", "{{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}}/form_field_types');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/form_field_types',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/form_field_types';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/form_field_types',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/form_field_types")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/form_field_types',
  headers: {
    'x-auth-token': '{{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}}/form_field_types',
  headers: {'x-auth-token': '{{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}}/form_field_types');

req.headers({
  'x-auth-token': '{{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}}/form_field_types',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/form_field_types';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/form_field_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}}/form_field_types" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/form_field_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 => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/form_field_types', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/form_field_types');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/form_field_types');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/form_field_types' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/form_field_types' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/form_field_types", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/form_field_types"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/form_field_types"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/form_field_types")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/form_field_types') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/form_field_types";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/form_field_types \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/form_field_types \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/form_field_types
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/form_field_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()
POST Add new form
{{baseUrl}}/forms
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "form_template_id": "",
  "project_id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/forms");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"form_template_id\": \"\",\n  \"project_id\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/forms" {:headers {:x-auth-token "{{apiKey}}"}
                                                  :content-type :json
                                                  :form-params {:form_template_id ""
                                                                :project_id ""}})
require "http/client"

url = "{{baseUrl}}/forms"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"form_template_id\": \"\",\n  \"project_id\": \"\"\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}}/forms"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"form_template_id\": \"\",\n  \"project_id\": \"\"\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}}/forms");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"form_template_id\": \"\",\n  \"project_id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/forms"

	payload := strings.NewReader("{\n  \"form_template_id\": \"\",\n  \"project_id\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/forms HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 48

{
  "form_template_id": "",
  "project_id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/forms")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"form_template_id\": \"\",\n  \"project_id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/forms"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"form_template_id\": \"\",\n  \"project_id\": \"\"\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  \"form_template_id\": \"\",\n  \"project_id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/forms")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/forms")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"form_template_id\": \"\",\n  \"project_id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  form_template_id: '',
  project_id: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/forms');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/forms',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {form_template_id: '', project_id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/forms';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"form_template_id":"","project_id":""}'
};

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}}/forms',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "form_template_id": "",\n  "project_id": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"form_template_id\": \"\",\n  \"project_id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/forms")
  .post(body)
  .addHeader("x-auth-token", "{{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/forms',
  headers: {
    'x-auth-token': '{{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({form_template_id: '', project_id: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/forms',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {form_template_id: '', project_id: ''},
  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}}/forms');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  form_template_id: '',
  project_id: ''
});

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}}/forms',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {form_template_id: '', project_id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/forms';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"form_template_id":"","project_id":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"form_template_id": @"",
                              @"project_id": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/forms"]
                                                       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}}/forms" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"form_template_id\": \"\",\n  \"project_id\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/forms",
  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([
    'form_template_id' => '',
    'project_id' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/forms', [
  'body' => '{
  "form_template_id": "",
  "project_id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/forms');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'form_template_id' => '',
  'project_id' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'form_template_id' => '',
  'project_id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/forms');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/forms' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "form_template_id": "",
  "project_id": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/forms' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "form_template_id": "",
  "project_id": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"form_template_id\": \"\",\n  \"project_id\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/forms", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/forms"

payload = {
    "form_template_id": "",
    "project_id": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/forms"

payload <- "{\n  \"form_template_id\": \"\",\n  \"project_id\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/forms")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"form_template_id\": \"\",\n  \"project_id\": \"\"\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/forms') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"form_template_id\": \"\",\n  \"project_id\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/forms";

    let payload = json!({
        "form_template_id": "",
        "project_id": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/forms \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "form_template_id": "",
  "project_id": ""
}'
echo '{
  "form_template_id": "",
  "project_id": ""
}' |  \
  http POST {{baseUrl}}/forms \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "form_template_id": "",\n  "project_id": ""\n}' \
  --output-document \
  - {{baseUrl}}/forms
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "form_template_id": "",
  "project_id": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/forms")! 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 Delete a form
{{baseUrl}}/forms/:form_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

form_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/forms/:form_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/forms/:form_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/forms/:form_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/forms/:form_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/forms/:form_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/forms/:form_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/forms/:form_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/forms/:form_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/forms/:form_id"))
    .header("x-auth-token", "{{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}}/forms/:form_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/forms/:form_id")
  .header("x-auth-token", "{{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}}/forms/:form_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/forms/:form_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/forms/:form_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/forms/:form_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/forms/:form_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/forms/:form_id',
  headers: {
    'x-auth-token': '{{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}}/forms/:form_id',
  headers: {'x-auth-token': '{{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}}/forms/:form_id');

req.headers({
  'x-auth-token': '{{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}}/forms/:form_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/forms/:form_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/forms/:form_id"]
                                                       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}}/forms/:form_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/forms/:form_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/forms/:form_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/forms/:form_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/forms/:form_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/forms/:form_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/forms/:form_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/forms/:form_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/forms/:form_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/forms/:form_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/forms/:form_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/forms/:form_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/forms/:form_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/forms/:form_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/forms/:form_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/forms/:form_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/forms/:form_id")! 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()
PUT Edit a form
{{baseUrl}}/forms/:form_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

form_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/forms/:form_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/forms/:form_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/forms/:form_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/forms/:form_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/forms/:form_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/forms/:form_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/forms/:form_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/forms/:form_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/forms/:form_id"))
    .header("x-auth-token", "{{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}}/forms/:form_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/forms/:form_id")
  .header("x-auth-token", "{{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}}/forms/:form_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/forms/:form_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/forms/:form_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/forms/:form_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/forms/:form_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/forms/:form_id',
  headers: {
    'x-auth-token': '{{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}}/forms/:form_id',
  headers: {'x-auth-token': '{{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}}/forms/:form_id');

req.headers({
  'x-auth-token': '{{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}}/forms/:form_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/forms/:form_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/forms/:form_id"]
                                                       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}}/forms/:form_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/forms/:form_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/forms/:form_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/forms/:form_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/forms/:form_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/forms/:form_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/forms/:form_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/forms/:form_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/forms/:form_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/forms/:form_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/forms/:form_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/forms/:form_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/forms/:form_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/forms/:form_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/forms/:form_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/forms/:form_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/forms/:form_id")! 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()
GET Generate time form pdf
{{baseUrl}}/forms/view_time_form_pdf/:form_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

form_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/forms/view_time_form_pdf/:form_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/forms/view_time_form_pdf/:form_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/forms/view_time_form_pdf/:form_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/forms/view_time_form_pdf/:form_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/forms/view_time_form_pdf/:form_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/forms/view_time_form_pdf/:form_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/forms/view_time_form_pdf/:form_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/forms/view_time_form_pdf/:form_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/forms/view_time_form_pdf/:form_id"))
    .header("x-auth-token", "{{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}}/forms/view_time_form_pdf/:form_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/forms/view_time_form_pdf/:form_id")
  .header("x-auth-token", "{{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}}/forms/view_time_form_pdf/:form_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/forms/view_time_form_pdf/:form_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/forms/view_time_form_pdf/:form_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/forms/view_time_form_pdf/:form_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/forms/view_time_form_pdf/:form_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/forms/view_time_form_pdf/:form_id',
  headers: {
    'x-auth-token': '{{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}}/forms/view_time_form_pdf/:form_id',
  headers: {'x-auth-token': '{{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}}/forms/view_time_form_pdf/:form_id');

req.headers({
  'x-auth-token': '{{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}}/forms/view_time_form_pdf/:form_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/forms/view_time_form_pdf/:form_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/forms/view_time_form_pdf/:form_id"]
                                                       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}}/forms/view_time_form_pdf/:form_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/forms/view_time_form_pdf/:form_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/forms/view_time_form_pdf/:form_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/forms/view_time_form_pdf/:form_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/forms/view_time_form_pdf/:form_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/forms/view_time_form_pdf/:form_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/forms/view_time_form_pdf/:form_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/forms/view_time_form_pdf/:form_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/forms/view_time_form_pdf/:form_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/forms/view_time_form_pdf/:form_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/forms/view_time_form_pdf/:form_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/forms/view_time_form_pdf/:form_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/forms/view_time_form_pdf/:form_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/forms/view_time_form_pdf/:form_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/forms/view_time_form_pdf/:form_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/forms/view_time_form_pdf/:form_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/forms/view_time_form_pdf/:form_id")! 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 array of forms
{{baseUrl}}/forms
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/forms");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/forms" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/forms"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/forms"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/forms");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/forms"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/forms HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/forms")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/forms"))
    .header("x-auth-token", "{{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}}/forms")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/forms")
  .header("x-auth-token", "{{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}}/forms');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/forms',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/forms';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/forms',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/forms")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/forms',
  headers: {
    'x-auth-token': '{{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}}/forms',
  headers: {'x-auth-token': '{{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}}/forms');

req.headers({
  'x-auth-token': '{{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}}/forms',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/forms';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/forms"]
                                                       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}}/forms" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/forms",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/forms', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/forms');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/forms');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/forms' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/forms' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/forms", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/forms"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/forms"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/forms")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/forms') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/forms";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/forms \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/forms \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/forms
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/forms")! 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()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/forms/undelete/:form_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/forms/undelete/:form_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/forms/undelete/:form_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/forms/undelete/:form_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/forms/undelete/:form_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/forms/undelete/:form_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/forms/undelete/:form_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/forms/undelete/:form_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/forms/undelete/:form_id"))
    .header("x-auth-token", "{{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}}/forms/undelete/:form_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/forms/undelete/:form_id")
  .header("x-auth-token", "{{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}}/forms/undelete/:form_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/forms/undelete/:form_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/forms/undelete/:form_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/forms/undelete/:form_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/forms/undelete/:form_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/forms/undelete/:form_id',
  headers: {
    'x-auth-token': '{{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}}/forms/undelete/:form_id',
  headers: {'x-auth-token': '{{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}}/forms/undelete/:form_id');

req.headers({
  'x-auth-token': '{{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}}/forms/undelete/:form_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/forms/undelete/:form_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/forms/undelete/:form_id"]
                                                       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}}/forms/undelete/:form_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/forms/undelete/:form_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/forms/undelete/:form_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/forms/undelete/:form_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/forms/undelete/:form_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/forms/undelete/:form_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/forms/undelete/:form_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/forms/undelete/:form_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/forms/undelete/:form_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/forms/undelete/:form_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/forms/undelete/:form_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/forms/undelete/:form_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/forms/undelete/:form_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/forms/undelete/:form_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/forms/undelete/:form_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/forms/undelete/:form_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/forms/undelete/:form_id")! 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 View form
{{baseUrl}}/forms/:form_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

form_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/forms/:form_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/forms/:form_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/forms/:form_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/forms/:form_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/forms/:form_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/forms/:form_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/forms/:form_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/forms/:form_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/forms/:form_id"))
    .header("x-auth-token", "{{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}}/forms/:form_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/forms/:form_id")
  .header("x-auth-token", "{{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}}/forms/:form_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/forms/:form_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/forms/:form_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/forms/:form_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/forms/:form_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/forms/:form_id',
  headers: {
    'x-auth-token': '{{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}}/forms/:form_id',
  headers: {'x-auth-token': '{{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}}/forms/:form_id');

req.headers({
  'x-auth-token': '{{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}}/forms/:form_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/forms/:form_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/forms/:form_id"]
                                                       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}}/forms/:form_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/forms/:form_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/forms/:form_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/forms/:form_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/forms/:form_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/forms/:form_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/forms/:form_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/forms/:form_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/forms/:form_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/forms/:form_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/forms/:form_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/forms/:form_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/forms/:form_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/forms/:form_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/forms/:form_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/forms/:form_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/forms/:form_id")! 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 array of form_templates for your company
{{baseUrl}}/form_templates
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/form_templates");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/form_templates" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/form_templates"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/form_templates"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/form_templates");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/form_templates"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/form_templates HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/form_templates")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/form_templates"))
    .header("x-auth-token", "{{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}}/form_templates")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/form_templates")
  .header("x-auth-token", "{{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}}/form_templates');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/form_templates',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/form_templates';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/form_templates',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/form_templates")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/form_templates',
  headers: {
    'x-auth-token': '{{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}}/form_templates',
  headers: {'x-auth-token': '{{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}}/form_templates');

req.headers({
  'x-auth-token': '{{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}}/form_templates',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/form_templates';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/form_templates"]
                                                       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}}/form_templates" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/form_templates",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/form_templates', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/form_templates');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/form_templates');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/form_templates' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/form_templates' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/form_templates", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/form_templates"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/form_templates"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/form_templates")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/form_templates') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/form_templates";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/form_templates \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/form_templates \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/form_templates
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/form_templates")! 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 View one form template
{{baseUrl}}/form_templates/:form_template_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

form_template_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/form_templates/:form_template_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/form_templates/:form_template_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/form_templates/:form_template_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/form_templates/:form_template_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/form_templates/:form_template_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/form_templates/:form_template_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/form_templates/:form_template_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/form_templates/:form_template_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/form_templates/:form_template_id"))
    .header("x-auth-token", "{{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}}/form_templates/:form_template_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/form_templates/:form_template_id")
  .header("x-auth-token", "{{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}}/form_templates/:form_template_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/form_templates/:form_template_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/form_templates/:form_template_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/form_templates/:form_template_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/form_templates/:form_template_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/form_templates/:form_template_id',
  headers: {
    'x-auth-token': '{{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}}/form_templates/:form_template_id',
  headers: {'x-auth-token': '{{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}}/form_templates/:form_template_id');

req.headers({
  'x-auth-token': '{{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}}/form_templates/:form_template_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/form_templates/:form_template_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/form_templates/:form_template_id"]
                                                       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}}/form_templates/:form_template_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/form_templates/:form_template_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/form_templates/:form_template_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/form_templates/:form_template_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/form_templates/:form_template_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/form_templates/:form_template_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/form_templates/:form_template_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/form_templates/:form_template_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/form_templates/:form_template_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/form_templates/:form_template_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/form_templates/:form_template_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/form_templates/:form_template_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/form_templates/:form_template_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/form_templates/:form_template_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/form_templates/:form_template_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/form_templates/:form_template_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/form_templates/:form_template_id")! 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 Authenticate to Billys
{{baseUrl}}/integrations/billysAuthenticate
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/integrations/billysAuthenticate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/integrations/billysAuthenticate" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/integrations/billysAuthenticate"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
}

response = HTTP::Client.post url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/integrations/billysAuthenticate"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/integrations/billysAuthenticate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/integrations/billysAuthenticate"

	req, _ := http.NewRequest("POST", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/integrations/billysAuthenticate HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/integrations/billysAuthenticate")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/integrations/billysAuthenticate"))
    .header("x-auth-token", "{{apiKey}}")
    .method("POST", 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}}/integrations/billysAuthenticate")
  .post(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/integrations/billysAuthenticate")
  .header("x-auth-token", "{{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('POST', '{{baseUrl}}/integrations/billysAuthenticate');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/integrations/billysAuthenticate',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/integrations/billysAuthenticate';
const options = {method: 'POST', headers: {'x-auth-token': '{{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}}/integrations/billysAuthenticate',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/integrations/billysAuthenticate")
  .post(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/integrations/billysAuthenticate',
  headers: {
    'x-auth-token': '{{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: 'POST',
  url: '{{baseUrl}}/integrations/billysAuthenticate',
  headers: {'x-auth-token': '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/integrations/billysAuthenticate');

req.headers({
  'x-auth-token': '{{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: 'POST',
  url: '{{baseUrl}}/integrations/billysAuthenticate',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/integrations/billysAuthenticate';
const options = {method: 'POST', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/integrations/billysAuthenticate"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[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}}/integrations/billysAuthenticate" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/integrations/billysAuthenticate",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/integrations/billysAuthenticate', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/integrations/billysAuthenticate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/integrations/billysAuthenticate');
$request->setRequestMethod('POST');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/integrations/billysAuthenticate' -Method POST -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/integrations/billysAuthenticate' -Method POST -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("POST", "/baseUrl/integrations/billysAuthenticate", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/integrations/billysAuthenticate"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.post(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/integrations/billysAuthenticate"

response <- VERB("POST", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/integrations/billysAuthenticate")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/integrations/billysAuthenticate') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/integrations/billysAuthenticate";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/integrations/billysAuthenticate \
  --header 'x-auth-token: {{apiKey}}'
http POST {{baseUrl}}/integrations/billysAuthenticate \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/integrations/billysAuthenticate
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/integrations/billysAuthenticate")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
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 Force Synchronization with ERP systems
{{baseUrl}}/integrations/contactsSync
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/integrations/contactsSync");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/integrations/contactsSync")
require "http/client"

url = "{{baseUrl}}/integrations/contactsSync"

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}}/integrations/contactsSync"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/integrations/contactsSync");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/integrations/contactsSync"

	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/integrations/contactsSync HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/integrations/contactsSync")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/integrations/contactsSync"))
    .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}}/integrations/contactsSync")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/integrations/contactsSync")
  .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}}/integrations/contactsSync');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/integrations/contactsSync'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/integrations/contactsSync';
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}}/integrations/contactsSync',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/integrations/contactsSync")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/integrations/contactsSync',
  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}}/integrations/contactsSync'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/integrations/contactsSync');

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}}/integrations/contactsSync'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/integrations/contactsSync';
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}}/integrations/contactsSync"]
                                                       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}}/integrations/contactsSync" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/integrations/contactsSync",
  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}}/integrations/contactsSync');

echo $response->getBody();
setUrl('{{baseUrl}}/integrations/contactsSync');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/integrations/contactsSync');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/integrations/contactsSync' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/integrations/contactsSync' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/integrations/contactsSync")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/integrations/contactsSync"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/integrations/contactsSync"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/integrations/contactsSync")

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/integrations/contactsSync') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/integrations/contactsSync";

    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}}/integrations/contactsSync
http GET {{baseUrl}}/integrations/contactsSync
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/integrations/contactsSync
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/integrations/contactsSync")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET Get integrations list
{{baseUrl}}/integrations
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/integrations");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/integrations")
require "http/client"

url = "{{baseUrl}}/integrations"

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}}/integrations"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/integrations");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/integrations"

	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/integrations HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/integrations")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/integrations"))
    .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}}/integrations")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/integrations")
  .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}}/integrations');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/integrations'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/integrations';
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}}/integrations',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/integrations")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/integrations',
  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}}/integrations'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/integrations');

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}}/integrations'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/integrations';
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}}/integrations"]
                                                       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}}/integrations" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/integrations",
  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}}/integrations');

echo $response->getBody();
setUrl('{{baseUrl}}/integrations');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/integrations');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/integrations' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/integrations' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/integrations")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/integrations"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/integrations"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/integrations")

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/integrations') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/integrations";

    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}}/integrations
http GET {{baseUrl}}/integrations
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/integrations
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/integrations")! 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 Sync products from erp integration
{{baseUrl}}/integrations/productsSync
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/integrations/productsSync");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/integrations/productsSync" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/integrations/productsSync"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/integrations/productsSync"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/integrations/productsSync");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/integrations/productsSync"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/integrations/productsSync HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/integrations/productsSync")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/integrations/productsSync"))
    .header("x-auth-token", "{{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}}/integrations/productsSync")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/integrations/productsSync")
  .header("x-auth-token", "{{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}}/integrations/productsSync');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/integrations/productsSync',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/integrations/productsSync';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/integrations/productsSync',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/integrations/productsSync")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/integrations/productsSync',
  headers: {
    'x-auth-token': '{{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}}/integrations/productsSync',
  headers: {'x-auth-token': '{{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}}/integrations/productsSync');

req.headers({
  'x-auth-token': '{{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}}/integrations/productsSync',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/integrations/productsSync';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/integrations/productsSync"]
                                                       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}}/integrations/productsSync" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/integrations/productsSync",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/integrations/productsSync', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/integrations/productsSync');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/integrations/productsSync');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/integrations/productsSync' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/integrations/productsSync' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/integrations/productsSync", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/integrations/productsSync"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/integrations/productsSync"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/integrations/productsSync")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/integrations/productsSync') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/integrations/productsSync";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/integrations/productsSync \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/integrations/productsSync \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/integrations/productsSync
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/integrations/productsSync")! 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 View integration details
{{baseUrl}}/integrations/:integration_id
QUERY PARAMS

integration_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/integrations/:integration_id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/integrations/:integration_id")
require "http/client"

url = "{{baseUrl}}/integrations/:integration_id"

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}}/integrations/:integration_id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/integrations/:integration_id");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/integrations/:integration_id"

	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/integrations/:integration_id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/integrations/:integration_id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/integrations/:integration_id"))
    .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}}/integrations/:integration_id")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/integrations/:integration_id")
  .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}}/integrations/:integration_id');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/integrations/:integration_id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/integrations/:integration_id';
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}}/integrations/:integration_id',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/integrations/:integration_id")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/integrations/:integration_id',
  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}}/integrations/:integration_id'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/integrations/:integration_id');

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}}/integrations/:integration_id'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/integrations/:integration_id';
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}}/integrations/:integration_id"]
                                                       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}}/integrations/:integration_id" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/integrations/:integration_id",
  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}}/integrations/:integration_id');

echo $response->getBody();
setUrl('{{baseUrl}}/integrations/:integration_id');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/integrations/:integration_id');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/integrations/:integration_id' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/integrations/:integration_id' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/integrations/:integration_id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/integrations/:integration_id"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/integrations/:integration_id"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/integrations/:integration_id")

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/integrations/:integration_id') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/integrations/:integration_id";

    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}}/integrations/:integration_id
http GET {{baseUrl}}/integrations/:integration_id
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/integrations/:integration_id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/integrations/:integration_id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET Get an invoice emails
{{baseUrl}}/invoices/:invoice_id/emails/:email_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices/:invoice_id/emails/:email_id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/invoices/:invoice_id/emails/:email_id")
require "http/client"

url = "{{baseUrl}}/invoices/:invoice_id/emails/:email_id"

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}}/invoices/:invoice_id/emails/:email_id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoices/:invoice_id/emails/:email_id");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices/:invoice_id/emails/:email_id"

	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/invoices/:invoice_id/emails/:email_id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/invoices/:invoice_id/emails/:email_id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices/:invoice_id/emails/:email_id"))
    .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}}/invoices/:invoice_id/emails/:email_id")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/invoices/:invoice_id/emails/:email_id")
  .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}}/invoices/:invoice_id/emails/:email_id');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/invoices/:invoice_id/emails/:email_id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices/:invoice_id/emails/:email_id';
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}}/invoices/:invoice_id/emails/:email_id',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoices/:invoice_id/emails/:email_id")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoices/:invoice_id/emails/:email_id',
  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}}/invoices/:invoice_id/emails/:email_id'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/invoices/:invoice_id/emails/:email_id');

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}}/invoices/:invoice_id/emails/:email_id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoices/:invoice_id/emails/:email_id';
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}}/invoices/:invoice_id/emails/:email_id"]
                                                       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}}/invoices/:invoice_id/emails/:email_id" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices/:invoice_id/emails/:email_id",
  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}}/invoices/:invoice_id/emails/:email_id');

echo $response->getBody();
setUrl('{{baseUrl}}/invoices/:invoice_id/emails/:email_id');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoices/:invoice_id/emails/:email_id');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices/:invoice_id/emails/:email_id' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices/:invoice_id/emails/:email_id' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/invoices/:invoice_id/emails/:email_id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices/:invoice_id/emails/:email_id"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices/:invoice_id/emails/:email_id"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices/:invoice_id/emails/:email_id")

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/invoices/:invoice_id/emails/:email_id') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoices/:invoice_id/emails/:email_id";

    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}}/invoices/:invoice_id/emails/:email_id
http GET {{baseUrl}}/invoices/:invoice_id/emails/:email_id
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/invoices/:invoice_id/emails/:email_id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices/:invoice_id/emails/:email_id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST Create a new invoice file
{{baseUrl}}/invoices/:invoice_id/files
BODY formUrlEncoded

file_id
invoice_id
type
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices/:invoice_id/files");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/x-www-form-urlencoded");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "file_id=&invoice_id=&type=");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/invoices/:invoice_id/files" {:form-params {:file_id ""
                                                                                     :invoice_id ""
                                                                                     :type ""}})
require "http/client"

url = "{{baseUrl}}/invoices/:invoice_id/files"
headers = HTTP::Headers{
  "content-type" => "application/x-www-form-urlencoded"
}
reqBody = "file_id=&invoice_id=&type="

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}}/invoices/:invoice_id/files"),
    Content = new FormUrlEncodedContent(new Dictionary
    {
        { "file_id", "" },
        { "invoice_id", "" },
        { "type", "" },
    }),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoices/:invoice_id/files");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/x-www-form-urlencoded");
request.AddParameter("application/x-www-form-urlencoded", "file_id=&invoice_id=&type=", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices/:invoice_id/files"

	payload := strings.NewReader("file_id=&invoice_id=&type=")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/x-www-form-urlencoded")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/invoices/:invoice_id/files HTTP/1.1
Content-Type: application/x-www-form-urlencoded
Host: example.com
Content-Length: 26

file_id=&invoice_id=&type=
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/invoices/:invoice_id/files")
  .setHeader("content-type", "application/x-www-form-urlencoded")
  .setBody("file_id=&invoice_id=&type=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices/:invoice_id/files"))
    .header("content-type", "application/x-www-form-urlencoded")
    .method("POST", HttpRequest.BodyPublishers.ofString("file_id=&invoice_id=&type="))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/x-www-form-urlencoded");
RequestBody body = RequestBody.create(mediaType, "file_id=&invoice_id=&type=");
Request request = new Request.Builder()
  .url("{{baseUrl}}/invoices/:invoice_id/files")
  .post(body)
  .addHeader("content-type", "application/x-www-form-urlencoded")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/invoices/:invoice_id/files")
  .header("content-type", "application/x-www-form-urlencoded")
  .body("file_id=&invoice_id=&type=")
  .asString();
const data = 'file_id=&invoice_id=&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}}/invoices/:invoice_id/files');
xhr.setRequestHeader('content-type', 'application/x-www-form-urlencoded');

xhr.send(data);
import axios from 'axios';

const encodedParams = new URLSearchParams();
encodedParams.set('file_id', '');
encodedParams.set('invoice_id', '');
encodedParams.set('type', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoices/:invoice_id/files',
  headers: {'content-type': 'application/x-www-form-urlencoded'},
  data: encodedParams,
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices/:invoice_id/files';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/x-www-form-urlencoded'},
  body: new URLSearchParams({file_id: '', invoice_id: '', 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}}/invoices/:invoice_id/files',
  method: 'POST',
  headers: {
    'content-type': 'application/x-www-form-urlencoded'
  },
  data: {
    file_id: '',
    invoice_id: '',
    type: ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/x-www-form-urlencoded")
val body = RequestBody.create(mediaType, "file_id=&invoice_id=&type=")
val request = Request.Builder()
  .url("{{baseUrl}}/invoices/:invoice_id/files")
  .post(body)
  .addHeader("content-type", "application/x-www-form-urlencoded")
  .build()

val response = client.newCall(request).execute()
const qs = require('querystring');
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoices/:invoice_id/files',
  headers: {
    'content-type': 'application/x-www-form-urlencoded'
  }
};

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(qs.stringify({file_id: '', invoice_id: '', type: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoices/:invoice_id/files',
  headers: {'content-type': 'application/x-www-form-urlencoded'},
  form: {file_id: '', invoice_id: '', type: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/invoices/:invoice_id/files');

req.headers({
  'content-type': 'application/x-www-form-urlencoded'
});

req.form({
  file_id: '',
  invoice_id: '',
  type: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;
const { URLSearchParams } = require('url');

const encodedParams = new URLSearchParams();
encodedParams.set('file_id', '');
encodedParams.set('invoice_id', '');
encodedParams.set('type', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoices/:invoice_id/files',
  headers: {'content-type': 'application/x-www-form-urlencoded'},
  data: encodedParams,
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const { URLSearchParams } = require('url');
const fetch = require('node-fetch');

const encodedParams = new URLSearchParams();
encodedParams.set('file_id', '');
encodedParams.set('invoice_id', '');
encodedParams.set('type', '');

const url = '{{baseUrl}}/invoices/:invoice_id/files';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/x-www-form-urlencoded'},
  body: encodedParams
};

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/x-www-form-urlencoded" };

NSMutableData *postData = [[NSMutableData alloc] initWithData:[@"file_id=" dataUsingEncoding:NSUTF8StringEncoding]];
[postData appendData:[@"&invoice_id=" dataUsingEncoding:NSUTF8StringEncoding]];
[postData appendData:[@"&type=" dataUsingEncoding:NSUTF8StringEncoding]];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoices/:invoice_id/files"]
                                                       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}}/invoices/:invoice_id/files" in
let headers = Header.add (Header.init ()) "content-type" "application/x-www-form-urlencoded" in
let body = Cohttp_lwt_body.of_string "file_id=&invoice_id=&type=" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices/:invoice_id/files",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => "file_id=&invoice_id=&type=",
  CURLOPT_HTTPHEADER => [
    "content-type: application/x-www-form-urlencoded"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/invoices/:invoice_id/files', [
  'form_params' => [
    'file_id' => '',
    'invoice_id' => '',
    'type' => ''
  ],
  'headers' => [
    'content-type' => 'application/x-www-form-urlencoded',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoices/:invoice_id/files');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/x-www-form-urlencoded'
]);

$request->setContentType('application/x-www-form-urlencoded');
$request->setPostFields([
  'file_id' => '',
  'invoice_id' => '',
  'type' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(new http\QueryString([
  'file_id' => '',
  'invoice_id' => '',
  'type' => ''
]));

$request->setRequestUrl('{{baseUrl}}/invoices/:invoice_id/files');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/x-www-form-urlencoded'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/x-www-form-urlencoded")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices/:invoice_id/files' -Method POST -Headers $headers -ContentType 'application/x-www-form-urlencoded' -Body 'file_id=&invoice_id=&type='
$headers=@{}
$headers.Add("content-type", "application/x-www-form-urlencoded")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices/:invoice_id/files' -Method POST -Headers $headers -ContentType 'application/x-www-form-urlencoded' -Body 'file_id=&invoice_id=&type='
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "file_id=&invoice_id=&type="

headers = { 'content-type': "application/x-www-form-urlencoded" }

conn.request("POST", "/baseUrl/invoices/:invoice_id/files", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices/:invoice_id/files"

payload = {
    "file_id": "",
    "invoice_id": "",
    "type": ""
}
headers = {"content-type": "application/x-www-form-urlencoded"}

response = requests.post(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices/:invoice_id/files"

payload <- "file_id=&invoice_id=&type="

encode <- "form"

response <- VERB("POST", url, body = payload, content_type("application/x-www-form-urlencoded"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices/:invoice_id/files")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/x-www-form-urlencoded'
request.body = "file_id=&invoice_id=&type="

response = http.request(request)
puts response.read_body
require 'faraday'

data = {
  :file_id => "",
  :invoice_id => "",
  :type => "",
}

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/x-www-form-urlencoded'}
)

response = conn.post('/baseUrl/invoices/:invoice_id/files') do |req|
  req.body = URI.encode_www_form(data)
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoices/:invoice_id/files";

    let payload = json!({
        "file_id": "",
        "invoice_id": "",
        "type": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/x-www-form-urlencoded".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .form(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/invoices/:invoice_id/files \
  --header 'content-type: application/x-www-form-urlencoded' \
  --data file_id= \
  --data invoice_id= \
  --data type=
http --form POST {{baseUrl}}/invoices/:invoice_id/files \
  content-type:application/x-www-form-urlencoded \
  file_id='' \
  invoice_id='' \
  type=''
wget --quiet \
  --method POST \
  --header 'content-type: application/x-www-form-urlencoded' \
  --body-data 'file_id=&invoice_id=&type=' \
  --output-document \
  - {{baseUrl}}/invoices/:invoice_id/files
import Foundation

let headers = ["content-type": "application/x-www-form-urlencoded"]

let postData = NSMutableData(data: "file_id=".data(using: String.Encoding.utf8)!)
postData.append("&invoice_id=".data(using: String.Encoding.utf8)!)
postData.append("&type=".data(using: String.Encoding.utf8)!)

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices/:invoice_id/files")! 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 Delete invoice file
{{baseUrl}}/invoices/:invoice_id/files/:file_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

invoice_id
file_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices/:invoice_id/files/:file_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/invoices/:invoice_id/files/:file_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/invoices/:invoice_id/files/:file_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/invoices/:invoice_id/files/:file_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoices/:invoice_id/files/:file_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices/:invoice_id/files/:file_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/invoices/:invoice_id/files/:file_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/invoices/:invoice_id/files/:file_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices/:invoice_id/files/:file_id"))
    .header("x-auth-token", "{{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}}/invoices/:invoice_id/files/:file_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/invoices/:invoice_id/files/:file_id")
  .header("x-auth-token", "{{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}}/invoices/:invoice_id/files/:file_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/invoices/:invoice_id/files/:file_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices/:invoice_id/files/:file_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/invoices/:invoice_id/files/:file_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoices/:invoice_id/files/:file_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoices/:invoice_id/files/:file_id',
  headers: {
    'x-auth-token': '{{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}}/invoices/:invoice_id/files/:file_id',
  headers: {'x-auth-token': '{{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}}/invoices/:invoice_id/files/:file_id');

req.headers({
  'x-auth-token': '{{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}}/invoices/:invoice_id/files/:file_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoices/:invoice_id/files/:file_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoices/:invoice_id/files/:file_id"]
                                                       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}}/invoices/:invoice_id/files/:file_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices/:invoice_id/files/:file_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/invoices/:invoice_id/files/:file_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoices/:invoice_id/files/:file_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoices/:invoice_id/files/:file_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices/:invoice_id/files/:file_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices/:invoice_id/files/:file_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/invoices/:invoice_id/files/:file_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices/:invoice_id/files/:file_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices/:invoice_id/files/:file_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices/:invoice_id/files/:file_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/invoices/:invoice_id/files/:file_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoices/:invoice_id/files/:file_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoices/:invoice_id/files/:file_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/invoices/:invoice_id/files/:file_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/invoices/:invoice_id/files/:file_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices/:invoice_id/files/:file_id")! 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 Get an invoice files
{{baseUrl}}/invoices/:invoice_id/files/:file_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices/:invoice_id/files/:file_id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/invoices/:invoice_id/files/:file_id")
require "http/client"

url = "{{baseUrl}}/invoices/:invoice_id/files/:file_id"

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}}/invoices/:invoice_id/files/:file_id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoices/:invoice_id/files/:file_id");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices/:invoice_id/files/:file_id"

	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/invoices/:invoice_id/files/:file_id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/invoices/:invoice_id/files/:file_id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices/:invoice_id/files/:file_id"))
    .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}}/invoices/:invoice_id/files/:file_id")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/invoices/:invoice_id/files/:file_id")
  .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}}/invoices/:invoice_id/files/:file_id');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/invoices/:invoice_id/files/:file_id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices/:invoice_id/files/:file_id';
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}}/invoices/:invoice_id/files/:file_id',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoices/:invoice_id/files/:file_id")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoices/:invoice_id/files/:file_id',
  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}}/invoices/:invoice_id/files/:file_id'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/invoices/:invoice_id/files/:file_id');

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}}/invoices/:invoice_id/files/:file_id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoices/:invoice_id/files/:file_id';
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}}/invoices/:invoice_id/files/:file_id"]
                                                       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}}/invoices/:invoice_id/files/:file_id" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices/:invoice_id/files/:file_id",
  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}}/invoices/:invoice_id/files/:file_id');

echo $response->getBody();
setUrl('{{baseUrl}}/invoices/:invoice_id/files/:file_id');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoices/:invoice_id/files/:file_id');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices/:invoice_id/files/:file_id' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices/:invoice_id/files/:file_id' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/invoices/:invoice_id/files/:file_id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices/:invoice_id/files/:file_id"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices/:invoice_id/files/:file_id"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices/:invoice_id/files/:file_id")

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/invoices/:invoice_id/files/:file_id') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoices/:invoice_id/files/:file_id";

    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}}/invoices/:invoice_id/files/:file_id
http GET {{baseUrl}}/invoices/:invoice_id/files/:file_id
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/invoices/:invoice_id/files/:file_id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices/:invoice_id/files/:file_id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET Get list of invoice files
{{baseUrl}}/invoices/:invoice_id/files
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices/:invoice_id/files");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/invoices/:invoice_id/files")
require "http/client"

url = "{{baseUrl}}/invoices/:invoice_id/files"

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}}/invoices/:invoice_id/files"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoices/:invoice_id/files");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices/:invoice_id/files"

	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/invoices/:invoice_id/files HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/invoices/:invoice_id/files")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices/:invoice_id/files"))
    .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}}/invoices/:invoice_id/files")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/invoices/:invoice_id/files")
  .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}}/invoices/:invoice_id/files');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/invoices/:invoice_id/files'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices/:invoice_id/files';
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}}/invoices/:invoice_id/files',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoices/:invoice_id/files")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoices/:invoice_id/files',
  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}}/invoices/:invoice_id/files'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/invoices/:invoice_id/files');

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}}/invoices/:invoice_id/files'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoices/:invoice_id/files';
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}}/invoices/:invoice_id/files"]
                                                       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}}/invoices/:invoice_id/files" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices/:invoice_id/files",
  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}}/invoices/:invoice_id/files');

echo $response->getBody();
setUrl('{{baseUrl}}/invoices/:invoice_id/files');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoices/:invoice_id/files');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices/:invoice_id/files' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices/:invoice_id/files' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/invoices/:invoice_id/files")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices/:invoice_id/files"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices/:invoice_id/files"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices/:invoice_id/files")

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/invoices/:invoice_id/files') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoices/:invoice_id/files";

    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}}/invoices/:invoice_id/files
http GET {{baseUrl}}/invoices/:invoice_id/files
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/invoices/:invoice_id/files
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices/:invoice_id/files")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST Add invoice line text
{{baseUrl}}/invoice_line_texts/
HEADERS

X-Auth-Token
{{apiKey}}
BODY multipartForm

Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoice_line_texts/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/invoice_line_texts/" {:headers {:x-auth-token "{{apiKey}}"}
                                                                :multipart [{:name "html"
                                                                             :content ""} {:name "image"
                                                                             :content ""} {:name "invoice_id"
                                                                             :content ""} {:name "placement"
                                                                             :content ""}]})
require "http/client"

url = "{{baseUrl}}/invoice_line_texts/"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "multipart/form-data; boundary=---011000010111000001101001"
}
reqBody = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\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}}/invoice_line_texts/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new MultipartFormDataContent
    {
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "html",
                }
            }
        },
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "image",
                }
            }
        },
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "invoice_id",
                }
            }
        },
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "placement",
                }
            }
        },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoice_line_texts/");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001");
request.AddParameter("multipart/form-data; boundary=---011000010111000001101001", "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\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}}/invoice_line_texts/"

	payload := strings.NewReader("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/invoice_line_texts/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: multipart/form-data; boundary=---011000010111000001101001
Host: example.com
Content-Length: 365

-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001
Content-Disposition: form-data; name="invoice_id"


-----011000010111000001101001
Content-Disposition: form-data; name="placement"


-----011000010111000001101001--
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/invoice_line_texts/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .setBody("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\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}}/invoice_line_texts/"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
    .method("POST", HttpRequest.BodyPublishers.ofString("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");
Request request = new Request.Builder()
  .url("{{baseUrl}}/invoice_line_texts/")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/invoice_line_texts/")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .body("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
  .asString();
const data = new FormData();
data.append('html', '');
data.append('image', '');
data.append('invoice_id', '');
data.append('placement', '');

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/invoice_line_texts/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const form = new FormData();
form.append('html', '');
form.append('image', '');
form.append('invoice_id', '');
form.append('placement', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoice_line_texts/',
  headers: {
    'x-auth-token': '{{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}}/invoice_line_texts/';
const form = new FormData();
form.append('html', '');
form.append('image', '');
form.append('invoice_id', '');
form.append('placement', '');

const options = {method: 'POST', headers: {'x-auth-token': '{{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('html', '');
form.append('image', '');
form.append('invoice_id', '');
form.append('placement', '');

const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/invoice_line_texts/',
  method: 'POST',
  headers: {
    'x-auth-token': '{{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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
val request = Request.Builder()
  .url("{{baseUrl}}/invoice_line_texts/")
  .post(body)
  .addHeader("x-auth-token", "{{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/invoice_line_texts/',
  headers: {
    'x-auth-token': '{{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="html"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="image"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="invoice_id"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="placement"\r\n\r\n\r\n-----011000010111000001101001--\r\n');
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoice_line_texts/',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  formData: {html: '', image: '', invoice_id: '', placement: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/invoice_line_texts/');

req.headers({
  'x-auth-token': '{{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}}/invoice_line_texts/',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  data: '-----011000010111000001101001\r\nContent-Disposition: form-data; name="html"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="image"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="invoice_id"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="placement"\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('html', '');
formData.append('image', '');
formData.append('invoice_id', '');
formData.append('placement', '');

const url = '{{baseUrl}}/invoice_line_texts/';
const options = {method: 'POST', headers: {'x-auth-token': '{{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 = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"multipart/form-data; boundary=---011000010111000001101001" };
NSArray *parameters = @[ @{ @"name": @"html", @"value": @"" },
                         @{ @"name": @"image", @"value": @"" },
                         @{ @"name": @"invoice_id", @"value": @"" },
                         @{ @"name": @"placement", @"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}}/invoice_line_texts/"]
                                                       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}}/invoice_line_texts/" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "multipart/form-data; boundary=---011000010111000001101001");
] in
let body = Cohttp_lwt_body.of_string "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\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}}/invoice_line_texts/",
  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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\r\n\r\n\r\n-----011000010111000001101001--\r\n",
  CURLOPT_HTTPHEADER => [
    "content-type: multipart/form-data; boundary=---011000010111000001101001",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/invoice_line_texts/', [
  'headers' => [
    'content-type' => 'multipart/form-data; boundary=---011000010111000001101001',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoice_line_texts/');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'multipart/form-data; boundary=---011000010111000001101001'
]);

$request->setBody('-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001
Content-Disposition: form-data; name="invoice_id"


-----011000010111000001101001
Content-Disposition: form-data; name="placement"


-----011000010111000001101001--
');

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
addForm(null, null);

$request->setRequestUrl('{{baseUrl}}/invoice_line_texts/');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoice_line_texts/' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001
Content-Disposition: form-data; name="invoice_id"


-----011000010111000001101001
Content-Disposition: form-data; name="placement"


-----011000010111000001101001--
'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoice_line_texts/' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001
Content-Disposition: form-data; name="invoice_id"


-----011000010111000001101001
Content-Disposition: form-data; name="placement"


-----011000010111000001101001--
'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "multipart/form-data; boundary=---011000010111000001101001"
}

conn.request("POST", "/baseUrl/invoice_line_texts/", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoice_line_texts/"

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "multipart/form-data; boundary=---011000010111000001101001"
}

response = requests.post(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoice_line_texts/"

payload <- "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

encode <- "multipart"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("multipart/form-data"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoice_line_texts/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'multipart/form-data; boundary=---011000010111000001101001'
request.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\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/invoice_line_texts/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"invoice_id\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"placement\"\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}}/invoice_line_texts/";

    let form = reqwest::multipart::Form::new()
        .text("html", "")
        .text("image", "")
        .text("invoice_id", "")
        .text("placement", "");
    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoice_line_texts/ \
  --header 'content-type: multipart/form-data' \
  --header 'x-auth-token: {{apiKey}}' \
  --form html= \
  --form image= \
  --form invoice_id= \
  --form placement=
echo '-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001
Content-Disposition: form-data; name="invoice_id"


-----011000010111000001101001
Content-Disposition: form-data; name="placement"


-----011000010111000001101001--
' |  \
  http POST {{baseUrl}}/invoice_line_texts/ \
  content-type:'multipart/form-data; boundary=---011000010111000001101001' \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: multipart/form-data; boundary=---011000010111000001101001' \
  --body-data '-----011000010111000001101001\r\nContent-Disposition: form-data; name="html"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="image"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="invoice_id"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="placement"\r\n\r\n\r\n-----011000010111000001101001--\r\n' \
  --output-document \
  - {{baseUrl}}/invoice_line_texts/
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "multipart/form-data; boundary=---011000010111000001101001"
]
let parameters = [
  [
    "name": "html",
    "value": ""
  ],
  [
    "name": "image",
    "value": ""
  ],
  [
    "name": "invoice_id",
    "value": ""
  ],
  [
    "name": "placement",
    "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}}/invoice_line_texts/")! 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 invoice line
{{baseUrl}}/invoice_lines
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "child_invoice_lines": [
    {}
  ],
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_bundle_id": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoice_lines");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/invoice_lines" {:headers {:x-auth-token "{{apiKey}}"}
                                                          :content-type :json
                                                          :form-params {:child_invoice_lines [{}]
                                                                        :description ""
                                                                        :discount_percent 0
                                                                        :discount_text ""
                                                                        :invoice_id ""
                                                                        :name ""
                                                                        :product_bundle_id ""
                                                                        :product_id ""
                                                                        :quantity 0
                                                                        :selling_price ""
                                                                        :user_id ""}})
require "http/client"

url = "{{baseUrl}}/invoice_lines"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\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}}/invoice_lines"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\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}}/invoice_lines");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoice_lines"

	payload := strings.NewReader("{\n  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/invoice_lines HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 248

{
  "child_invoice_lines": [
    {}
  ],
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_bundle_id": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/invoice_lines")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoice_lines"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\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  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/invoice_lines")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/invoice_lines")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  child_invoice_lines: [
    {}
  ],
  description: '',
  discount_percent: 0,
  discount_text: '',
  invoice_id: '',
  name: '',
  product_bundle_id: '',
  product_id: '',
  quantity: 0,
  selling_price: '',
  user_id: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/invoice_lines');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoice_lines',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    child_invoice_lines: [{}],
    description: '',
    discount_percent: 0,
    discount_text: '',
    invoice_id: '',
    name: '',
    product_bundle_id: '',
    product_id: '',
    quantity: 0,
    selling_price: '',
    user_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoice_lines';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"child_invoice_lines":[{}],"description":"","discount_percent":0,"discount_text":"","invoice_id":"","name":"","product_bundle_id":"","product_id":"","quantity":0,"selling_price":"","user_id":""}'
};

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}}/invoice_lines',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "child_invoice_lines": [\n    {}\n  ],\n  "description": "",\n  "discount_percent": 0,\n  "discount_text": "",\n  "invoice_id": "",\n  "name": "",\n  "product_bundle_id": "",\n  "product_id": "",\n  "quantity": 0,\n  "selling_price": "",\n  "user_id": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/invoice_lines")
  .post(body)
  .addHeader("x-auth-token", "{{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/invoice_lines',
  headers: {
    'x-auth-token': '{{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({
  child_invoice_lines: [{}],
  description: '',
  discount_percent: 0,
  discount_text: '',
  invoice_id: '',
  name: '',
  product_bundle_id: '',
  product_id: '',
  quantity: 0,
  selling_price: '',
  user_id: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoice_lines',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    child_invoice_lines: [{}],
    description: '',
    discount_percent: 0,
    discount_text: '',
    invoice_id: '',
    name: '',
    product_bundle_id: '',
    product_id: '',
    quantity: 0,
    selling_price: '',
    user_id: ''
  },
  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}}/invoice_lines');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  child_invoice_lines: [
    {}
  ],
  description: '',
  discount_percent: 0,
  discount_text: '',
  invoice_id: '',
  name: '',
  product_bundle_id: '',
  product_id: '',
  quantity: 0,
  selling_price: '',
  user_id: ''
});

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}}/invoice_lines',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    child_invoice_lines: [{}],
    description: '',
    discount_percent: 0,
    discount_text: '',
    invoice_id: '',
    name: '',
    product_bundle_id: '',
    product_id: '',
    quantity: 0,
    selling_price: '',
    user_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoice_lines';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"child_invoice_lines":[{}],"description":"","discount_percent":0,"discount_text":"","invoice_id":"","name":"","product_bundle_id":"","product_id":"","quantity":0,"selling_price":"","user_id":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"child_invoice_lines": @[ @{  } ],
                              @"description": @"",
                              @"discount_percent": @0,
                              @"discount_text": @"",
                              @"invoice_id": @"",
                              @"name": @"",
                              @"product_bundle_id": @"",
                              @"product_id": @"",
                              @"quantity": @0,
                              @"selling_price": @"",
                              @"user_id": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoice_lines"]
                                                       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}}/invoice_lines" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoice_lines",
  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([
    'child_invoice_lines' => [
        [
                
        ]
    ],
    'description' => '',
    'discount_percent' => 0,
    'discount_text' => '',
    'invoice_id' => '',
    'name' => '',
    'product_bundle_id' => '',
    'product_id' => '',
    'quantity' => 0,
    'selling_price' => '',
    'user_id' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/invoice_lines', [
  'body' => '{
  "child_invoice_lines": [
    {}
  ],
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_bundle_id": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoice_lines');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'child_invoice_lines' => [
    [
        
    ]
  ],
  'description' => '',
  'discount_percent' => 0,
  'discount_text' => '',
  'invoice_id' => '',
  'name' => '',
  'product_bundle_id' => '',
  'product_id' => '',
  'quantity' => 0,
  'selling_price' => '',
  'user_id' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'child_invoice_lines' => [
    [
        
    ]
  ],
  'description' => '',
  'discount_percent' => 0,
  'discount_text' => '',
  'invoice_id' => '',
  'name' => '',
  'product_bundle_id' => '',
  'product_id' => '',
  'quantity' => 0,
  'selling_price' => '',
  'user_id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/invoice_lines');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoice_lines' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "child_invoice_lines": [
    {}
  ],
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_bundle_id": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoice_lines' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "child_invoice_lines": [
    {}
  ],
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_bundle_id": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/invoice_lines", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoice_lines"

payload = {
    "child_invoice_lines": [{}],
    "description": "",
    "discount_percent": 0,
    "discount_text": "",
    "invoice_id": "",
    "name": "",
    "product_bundle_id": "",
    "product_id": "",
    "quantity": 0,
    "selling_price": "",
    "user_id": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoice_lines"

payload <- "{\n  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoice_lines")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\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/invoice_lines') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"child_invoice_lines\": [\n    {}\n  ],\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_bundle_id\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoice_lines";

    let payload = json!({
        "child_invoice_lines": (json!({})),
        "description": "",
        "discount_percent": 0,
        "discount_text": "",
        "invoice_id": "",
        "name": "",
        "product_bundle_id": "",
        "product_id": "",
        "quantity": 0,
        "selling_price": "",
        "user_id": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoice_lines \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "child_invoice_lines": [
    {}
  ],
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_bundle_id": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
}'
echo '{
  "child_invoice_lines": [
    {}
  ],
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_bundle_id": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
}' |  \
  http POST {{baseUrl}}/invoice_lines \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "child_invoice_lines": [\n    {}\n  ],\n  "description": "",\n  "discount_percent": 0,\n  "discount_text": "",\n  "invoice_id": "",\n  "name": "",\n  "product_bundle_id": "",\n  "product_id": "",\n  "quantity": 0,\n  "selling_price": "",\n  "user_id": ""\n}' \
  --output-document \
  - {{baseUrl}}/invoice_lines
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "child_invoice_lines": [[]],
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_bundle_id": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoice_lines")! 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 Delete invoice line
{{baseUrl}}/invoice_lines/:invoice_line_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

invoice_line_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoice_lines/:invoice_line_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/invoice_lines/:invoice_line_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/invoice_lines/:invoice_line_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/invoice_lines/:invoice_line_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoice_lines/:invoice_line_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoice_lines/:invoice_line_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/invoice_lines/:invoice_line_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/invoice_lines/:invoice_line_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoice_lines/:invoice_line_id"))
    .header("x-auth-token", "{{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}}/invoice_lines/:invoice_line_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/invoice_lines/:invoice_line_id")
  .header("x-auth-token", "{{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}}/invoice_lines/:invoice_line_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/invoice_lines/:invoice_line_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoice_lines/:invoice_line_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/invoice_lines/:invoice_line_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoice_lines/:invoice_line_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoice_lines/:invoice_line_id',
  headers: {
    'x-auth-token': '{{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}}/invoice_lines/:invoice_line_id',
  headers: {'x-auth-token': '{{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}}/invoice_lines/:invoice_line_id');

req.headers({
  'x-auth-token': '{{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}}/invoice_lines/:invoice_line_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoice_lines/:invoice_line_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoice_lines/:invoice_line_id"]
                                                       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}}/invoice_lines/:invoice_line_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoice_lines/:invoice_line_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/invoice_lines/:invoice_line_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoice_lines/:invoice_line_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoice_lines/:invoice_line_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoice_lines/:invoice_line_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoice_lines/:invoice_line_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/invoice_lines/:invoice_line_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoice_lines/:invoice_line_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoice_lines/:invoice_line_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoice_lines/:invoice_line_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/invoice_lines/:invoice_line_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoice_lines/:invoice_line_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoice_lines/:invoice_line_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/invoice_lines/:invoice_line_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/invoice_lines/:invoice_line_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoice_lines/:invoice_line_id")! 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()
POST Edit invoice line text
{{baseUrl}}/invoice_line_texts/:invoice_line_text_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

invoice_line_text_id
BODY multipartForm

Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoice_line_texts/:invoice_line_text_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/invoice_line_texts/:invoice_line_text_id" {:headers {:x-auth-token "{{apiKey}}"}
                                                                                     :multipart [{:name "html"
                                                                                                  :content ""} {:name "image"
                                                                                                  :content ""}]})
require "http/client"

url = "{{baseUrl}}/invoice_line_texts/:invoice_line_text_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "multipart/form-data; boundary=---011000010111000001101001"
}
reqBody = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_texts/:invoice_line_text_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new MultipartFormDataContent
    {
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "html",
                }
            }
        },
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "image",
                }
            }
        },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoice_line_texts/:invoice_line_text_id");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001");
request.AddParameter("multipart/form-data; boundary=---011000010111000001101001", "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_texts/:invoice_line_text_id"

	payload := strings.NewReader("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/invoice_line_texts/:invoice_line_text_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: multipart/form-data; boundary=---011000010111000001101001
Host: example.com
Content-Length: 194

-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/invoice_line_texts/:invoice_line_text_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .setBody("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_texts/:invoice_line_text_id"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
    .method("POST", HttpRequest.BodyPublishers.ofString("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");
Request request = new Request.Builder()
  .url("{{baseUrl}}/invoice_line_texts/:invoice_line_text_id")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/invoice_line_texts/:invoice_line_text_id")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .body("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
  .asString();
const data = new FormData();
data.append('html', '');
data.append('image', '');

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/invoice_line_texts/:invoice_line_text_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const form = new FormData();
form.append('html', '');
form.append('image', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoice_line_texts/:invoice_line_text_id',
  headers: {
    'x-auth-token': '{{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}}/invoice_line_texts/:invoice_line_text_id';
const form = new FormData();
form.append('html', '');
form.append('image', '');

const options = {method: 'POST', headers: {'x-auth-token': '{{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('html', '');
form.append('image', '');

const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/invoice_line_texts/:invoice_line_text_id',
  method: 'POST',
  headers: {
    'x-auth-token': '{{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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
val request = Request.Builder()
  .url("{{baseUrl}}/invoice_line_texts/:invoice_line_text_id")
  .post(body)
  .addHeader("x-auth-token", "{{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/invoice_line_texts/:invoice_line_text_id',
  headers: {
    'x-auth-token': '{{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="html"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="image"\r\n\r\n\r\n-----011000010111000001101001--\r\n');
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoice_line_texts/:invoice_line_text_id',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  formData: {html: '', image: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/invoice_line_texts/:invoice_line_text_id');

req.headers({
  'x-auth-token': '{{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}}/invoice_line_texts/:invoice_line_text_id',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  data: '-----011000010111000001101001\r\nContent-Disposition: form-data; name="html"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="image"\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('html', '');
formData.append('image', '');

const url = '{{baseUrl}}/invoice_line_texts/:invoice_line_text_id';
const options = {method: 'POST', headers: {'x-auth-token': '{{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 = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"multipart/form-data; boundary=---011000010111000001101001" };
NSArray *parameters = @[ @{ @"name": @"html", @"value": @"" },
                         @{ @"name": @"image", @"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}}/invoice_line_texts/:invoice_line_text_id"]
                                                       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}}/invoice_line_texts/:invoice_line_text_id" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "multipart/form-data; boundary=---011000010111000001101001");
] in
let body = Cohttp_lwt_body.of_string "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_texts/:invoice_line_text_id",
  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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n",
  CURLOPT_HTTPHEADER => [
    "content-type: multipart/form-data; boundary=---011000010111000001101001",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/invoice_line_texts/:invoice_line_text_id', [
  'headers' => [
    'content-type' => 'multipart/form-data; boundary=---011000010111000001101001',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoice_line_texts/:invoice_line_text_id');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'multipart/form-data; boundary=---011000010111000001101001'
]);

$request->setBody('-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
');

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
addForm(null, null);

$request->setRequestUrl('{{baseUrl}}/invoice_line_texts/:invoice_line_text_id');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoice_line_texts/:invoice_line_text_id' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoice_line_texts/:invoice_line_text_id' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "multipart/form-data; boundary=---011000010111000001101001"
}

conn.request("POST", "/baseUrl/invoice_line_texts/:invoice_line_text_id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoice_line_texts/:invoice_line_text_id"

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "multipart/form-data; boundary=---011000010111000001101001"
}

response = requests.post(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoice_line_texts/:invoice_line_text_id"

payload <- "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

encode <- "multipart"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("multipart/form-data"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoice_line_texts/:invoice_line_text_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'multipart/form-data; boundary=---011000010111000001101001'
request.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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/invoice_line_texts/:invoice_line_text_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_texts/:invoice_line_text_id";

    let form = reqwest::multipart::Form::new()
        .text("html", "")
        .text("image", "");
    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoice_line_texts/:invoice_line_text_id \
  --header 'content-type: multipart/form-data' \
  --header 'x-auth-token: {{apiKey}}' \
  --form html= \
  --form image=
echo '-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
' |  \
  http POST {{baseUrl}}/invoice_line_texts/:invoice_line_text_id \
  content-type:'multipart/form-data; boundary=---011000010111000001101001' \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: multipart/form-data; boundary=---011000010111000001101001' \
  --body-data '-----011000010111000001101001\r\nContent-Disposition: form-data; name="html"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="image"\r\n\r\n\r\n-----011000010111000001101001--\r\n' \
  --output-document \
  - {{baseUrl}}/invoice_line_texts/:invoice_line_text_id
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "multipart/form-data; boundary=---011000010111000001101001"
]
let parameters = [
  [
    "name": "html",
    "value": ""
  ],
  [
    "name": "image",
    "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}}/invoice_line_texts/:invoice_line_text_id")! 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 Edit invoice line
{{baseUrl}}/invoice_lines/:invoice_line_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

invoice_line_id
BODY json

{
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoice_lines/:invoice_line_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/invoice_lines/:invoice_line_id" {:headers {:x-auth-token "{{apiKey}}"}
                                                                          :content-type :json
                                                                          :form-params {:description ""
                                                                                        :discount_percent 0
                                                                                        :discount_text ""
                                                                                        :invoice_id ""
                                                                                        :name ""
                                                                                        :product_id ""
                                                                                        :quantity 0
                                                                                        :selling_price ""
                                                                                        :user_id ""}})
require "http/client"

url = "{{baseUrl}}/invoice_lines/:invoice_line_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\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}}/invoice_lines/:invoice_line_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\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}}/invoice_lines/:invoice_line_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoice_lines/:invoice_line_id"

	payload := strings.NewReader("{\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("x-auth-token", "{{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/invoice_lines/:invoice_line_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 182

{
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/invoice_lines/:invoice_line_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoice_lines/:invoice_line_id"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\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  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/invoice_lines/:invoice_line_id")
  .put(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/invoice_lines/:invoice_line_id")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  description: '',
  discount_percent: 0,
  discount_text: '',
  invoice_id: '',
  name: '',
  product_id: '',
  quantity: 0,
  selling_price: '',
  user_id: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/invoice_lines/:invoice_line_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/invoice_lines/:invoice_line_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    description: '',
    discount_percent: 0,
    discount_text: '',
    invoice_id: '',
    name: '',
    product_id: '',
    quantity: 0,
    selling_price: '',
    user_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoice_lines/:invoice_line_id';
const options = {
  method: 'PUT',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"description":"","discount_percent":0,"discount_text":"","invoice_id":"","name":"","product_id":"","quantity":0,"selling_price":"","user_id":""}'
};

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}}/invoice_lines/:invoice_line_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "description": "",\n  "discount_percent": 0,\n  "discount_text": "",\n  "invoice_id": "",\n  "name": "",\n  "product_id": "",\n  "quantity": 0,\n  "selling_price": "",\n  "user_id": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/invoice_lines/:invoice_line_id")
  .put(body)
  .addHeader("x-auth-token", "{{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/invoice_lines/:invoice_line_id',
  headers: {
    'x-auth-token': '{{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({
  description: '',
  discount_percent: 0,
  discount_text: '',
  invoice_id: '',
  name: '',
  product_id: '',
  quantity: 0,
  selling_price: '',
  user_id: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/invoice_lines/:invoice_line_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    description: '',
    discount_percent: 0,
    discount_text: '',
    invoice_id: '',
    name: '',
    product_id: '',
    quantity: 0,
    selling_price: '',
    user_id: ''
  },
  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}}/invoice_lines/:invoice_line_id');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  description: '',
  discount_percent: 0,
  discount_text: '',
  invoice_id: '',
  name: '',
  product_id: '',
  quantity: 0,
  selling_price: '',
  user_id: ''
});

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}}/invoice_lines/:invoice_line_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    description: '',
    discount_percent: 0,
    discount_text: '',
    invoice_id: '',
    name: '',
    product_id: '',
    quantity: 0,
    selling_price: '',
    user_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoice_lines/:invoice_line_id';
const options = {
  method: 'PUT',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"description":"","discount_percent":0,"discount_text":"","invoice_id":"","name":"","product_id":"","quantity":0,"selling_price":"","user_id":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"description": @"",
                              @"discount_percent": @0,
                              @"discount_text": @"",
                              @"invoice_id": @"",
                              @"name": @"",
                              @"product_id": @"",
                              @"quantity": @0,
                              @"selling_price": @"",
                              @"user_id": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoice_lines/:invoice_line_id"]
                                                       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}}/invoice_lines/:invoice_line_id" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoice_lines/:invoice_line_id",
  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([
    'description' => '',
    'discount_percent' => 0,
    'discount_text' => '',
    'invoice_id' => '',
    'name' => '',
    'product_id' => '',
    'quantity' => 0,
    'selling_price' => '',
    'user_id' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/invoice_lines/:invoice_line_id', [
  'body' => '{
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoice_lines/:invoice_line_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'description' => '',
  'discount_percent' => 0,
  'discount_text' => '',
  'invoice_id' => '',
  'name' => '',
  'product_id' => '',
  'quantity' => 0,
  'selling_price' => '',
  'user_id' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'description' => '',
  'discount_percent' => 0,
  'discount_text' => '',
  'invoice_id' => '',
  'name' => '',
  'product_id' => '',
  'quantity' => 0,
  'selling_price' => '',
  'user_id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/invoice_lines/:invoice_line_id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoice_lines/:invoice_line_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoice_lines/:invoice_line_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/invoice_lines/:invoice_line_id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoice_lines/:invoice_line_id"

payload = {
    "description": "",
    "discount_percent": 0,
    "discount_text": "",
    "invoice_id": "",
    "name": "",
    "product_id": "",
    "quantity": 0,
    "selling_price": "",
    "user_id": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoice_lines/:invoice_line_id"

payload <- "{\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoice_lines/:invoice_line_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\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/invoice_lines/:invoice_line_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"description\": \"\",\n  \"discount_percent\": 0,\n  \"discount_text\": \"\",\n  \"invoice_id\": \"\",\n  \"name\": \"\",\n  \"product_id\": \"\",\n  \"quantity\": 0,\n  \"selling_price\": \"\",\n  \"user_id\": \"\"\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}}/invoice_lines/:invoice_line_id";

    let payload = json!({
        "description": "",
        "discount_percent": 0,
        "discount_text": "",
        "invoice_id": "",
        "name": "",
        "product_id": "",
        "quantity": 0,
        "selling_price": "",
        "user_id": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoice_lines/:invoice_line_id \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
}'
echo '{
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
}' |  \
  http PUT {{baseUrl}}/invoice_lines/:invoice_line_id \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "description": "",\n  "discount_percent": 0,\n  "discount_text": "",\n  "invoice_id": "",\n  "name": "",\n  "product_id": "",\n  "quantity": 0,\n  "selling_price": "",\n  "user_id": ""\n}' \
  --output-document \
  - {{baseUrl}}/invoice_lines/:invoice_line_id
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "description": "",
  "discount_percent": 0,
  "discount_text": "",
  "invoice_id": "",
  "name": "",
  "product_id": "",
  "quantity": 0,
  "selling_price": "",
  "user_id": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoice_lines/:invoice_line_id")! 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 View invoice line
{{baseUrl}}/invoice_lines/:invoice_line_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

invoice_line_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoice_lines/:invoice_line_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/invoice_lines/:invoice_line_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/invoice_lines/:invoice_line_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/invoice_lines/:invoice_line_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoice_lines/:invoice_line_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoice_lines/:invoice_line_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/invoice_lines/:invoice_line_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/invoice_lines/:invoice_line_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoice_lines/:invoice_line_id"))
    .header("x-auth-token", "{{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}}/invoice_lines/:invoice_line_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/invoice_lines/:invoice_line_id")
  .header("x-auth-token", "{{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}}/invoice_lines/:invoice_line_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/invoice_lines/:invoice_line_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoice_lines/:invoice_line_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/invoice_lines/:invoice_line_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoice_lines/:invoice_line_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoice_lines/:invoice_line_id',
  headers: {
    'x-auth-token': '{{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}}/invoice_lines/:invoice_line_id',
  headers: {'x-auth-token': '{{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}}/invoice_lines/:invoice_line_id');

req.headers({
  'x-auth-token': '{{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}}/invoice_lines/:invoice_line_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoice_lines/:invoice_line_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoice_lines/:invoice_line_id"]
                                                       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}}/invoice_lines/:invoice_line_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoice_lines/:invoice_line_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/invoice_lines/:invoice_line_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoice_lines/:invoice_line_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoice_lines/:invoice_line_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoice_lines/:invoice_line_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoice_lines/:invoice_line_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/invoice_lines/:invoice_line_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoice_lines/:invoice_line_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoice_lines/:invoice_line_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoice_lines/:invoice_line_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/invoice_lines/:invoice_line_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoice_lines/:invoice_line_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoice_lines/:invoice_line_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/invoice_lines/:invoice_line_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/invoice_lines/:invoice_line_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoice_lines/:invoice_line_id")! 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 View list of invoice lines
{{baseUrl}}/invoice_lines
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoice_lines");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/invoice_lines" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/invoice_lines"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/invoice_lines"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoice_lines");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoice_lines"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/invoice_lines HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/invoice_lines")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoice_lines"))
    .header("x-auth-token", "{{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}}/invoice_lines")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/invoice_lines")
  .header("x-auth-token", "{{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}}/invoice_lines');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/invoice_lines',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoice_lines';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/invoice_lines',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoice_lines")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoice_lines',
  headers: {
    'x-auth-token': '{{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}}/invoice_lines',
  headers: {'x-auth-token': '{{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}}/invoice_lines');

req.headers({
  'x-auth-token': '{{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}}/invoice_lines',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoice_lines';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoice_lines"]
                                                       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}}/invoice_lines" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoice_lines",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/invoice_lines', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoice_lines');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoice_lines');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoice_lines' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoice_lines' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/invoice_lines", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoice_lines"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoice_lines"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoice_lines")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/invoice_lines') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoice_lines";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoice_lines \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/invoice_lines \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/invoice_lines
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoice_lines")! 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 a new invoice line text template
{{baseUrl}}/invoice_line_text_template
BODY multipartForm

Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoice_line_text_template");

struct curl_slist *headers = NULL;
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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/invoice_line_text_template" {:multipart [{:name "html"
                                                                                    :content ""} {:name "image"
                                                                                    :content ""}]})
require "http/client"

url = "{{baseUrl}}/invoice_line_text_template"
headers = HTTP::Headers{
  "content-type" => "multipart/form-data; boundary=---011000010111000001101001"
}
reqBody = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_text_template"),
    Content = new MultipartFormDataContent
    {
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "html",
                }
            }
        },
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "image",
                }
            }
        },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoice_line_text_template");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001");
request.AddParameter("multipart/form-data; boundary=---011000010111000001101001", "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_text_template"

	payload := strings.NewReader("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")

	req, _ := http.NewRequest("POST", url, payload)

	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/invoice_line_text_template HTTP/1.1
Content-Type: multipart/form-data; boundary=---011000010111000001101001
Host: example.com
Content-Length: 194

-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/invoice_line_text_template")
  .setHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .setBody("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_text_template"))
    .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
    .method("POST", HttpRequest.BodyPublishers.ofString("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");
Request request = new Request.Builder()
  .url("{{baseUrl}}/invoice_line_text_template")
  .post(body)
  .addHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/invoice_line_text_template")
  .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .body("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
  .asString();
const data = new FormData();
data.append('html', '');
data.append('image', '');

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/invoice_line_text_template');

xhr.send(data);
import axios from 'axios';

const form = new FormData();
form.append('html', '');
form.append('image', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoice_line_text_template',
  headers: {'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}}/invoice_line_text_template';
const form = new FormData();
form.append('html', '');
form.append('image', '');

const options = {method: 'POST'};

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('html', '');
form.append('image', '');

const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/invoice_line_text_template',
  method: 'POST',
  headers: {},
  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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
val request = Request.Builder()
  .url("{{baseUrl}}/invoice_line_text_template")
  .post(body)
  .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/invoice_line_text_template',
  headers: {
    '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="html"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="image"\r\n\r\n\r\n-----011000010111000001101001--\r\n');
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoice_line_text_template',
  headers: {'content-type': 'multipart/form-data; boundary=---011000010111000001101001'},
  formData: {html: '', image: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/invoice_line_text_template');

req.headers({
  '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}}/invoice_line_text_template',
  headers: {'content-type': 'multipart/form-data; boundary=---011000010111000001101001'},
  data: '-----011000010111000001101001\r\nContent-Disposition: form-data; name="html"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="image"\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('html', '');
formData.append('image', '');

const url = '{{baseUrl}}/invoice_line_text_template';
const options = {method: 'POST'};
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 = @{ @"content-type": @"multipart/form-data; boundary=---011000010111000001101001" };
NSArray *parameters = @[ @{ @"name": @"html", @"value": @"" },
                         @{ @"name": @"image", @"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}}/invoice_line_text_template"]
                                                       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}}/invoice_line_text_template" in
let headers = Header.add (Header.init ()) "content-type" "multipart/form-data; boundary=---011000010111000001101001" in
let body = Cohttp_lwt_body.of_string "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_text_template",
  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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n",
  CURLOPT_HTTPHEADER => [
    "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}}/invoice_line_text_template', [
  'headers' => [
    'content-type' => 'multipart/form-data; boundary=---011000010111000001101001',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoice_line_text_template');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'multipart/form-data; boundary=---011000010111000001101001'
]);

$request->setBody('-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
');

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
addForm(null, null);

$request->setRequestUrl('{{baseUrl}}/invoice_line_text_template');
$request->setRequestMethod('POST');
$request->setBody($body);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoice_line_text_template' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
'
$headers=@{}
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoice_line_text_template' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

headers = { 'content-type': "multipart/form-data; boundary=---011000010111000001101001" }

conn.request("POST", "/baseUrl/invoice_line_text_template", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoice_line_text_template"

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"
headers = {"content-type": "multipart/form-data; boundary=---011000010111000001101001"}

response = requests.post(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoice_line_text_template"

payload <- "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

encode <- "multipart"

response <- VERB("POST", url, body = payload, content_type("multipart/form-data"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoice_line_text_template")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'multipart/form-data; boundary=---011000010111000001101001'
request.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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/invoice_line_text_template') do |req|
  req.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_text_template";

    let form = reqwest::multipart::Form::new()
        .text("html", "")
        .text("image", "");
    let mut headers = reqwest::header::HeaderMap::new();

    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}}/invoice_line_text_template \
  --header 'content-type: multipart/form-data' \
  --form html= \
  --form image=
echo '-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
' |  \
  http POST {{baseUrl}}/invoice_line_text_template \
  content-type:'multipart/form-data; boundary=---011000010111000001101001'
wget --quiet \
  --method POST \
  --header 'content-type: multipart/form-data; boundary=---011000010111000001101001' \
  --body-data '-----011000010111000001101001\r\nContent-Disposition: form-data; name="html"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="image"\r\n\r\n\r\n-----011000010111000001101001--\r\n' \
  --output-document \
  - {{baseUrl}}/invoice_line_text_template
import Foundation

let headers = ["content-type": "multipart/form-data; boundary=---011000010111000001101001"]
let parameters = [
  [
    "name": "html",
    "value": ""
  ],
  [
    "name": "image",
    "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}}/invoice_line_text_template")! 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 Delete an invoice line text template
{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/invoice_line_text_template/:invoice_line_text_template_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/invoice_line_text_template/:invoice_line_text_template_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"))
    .header("x-auth-token", "{{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}}/invoice_line_text_template/:invoice_line_text_template_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")
  .header("x-auth-token", "{{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}}/invoice_line_text_template/:invoice_line_text_template_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/invoice_line_text_template/:invoice_line_text_template_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoice_line_text_template/:invoice_line_text_template_id',
  headers: {
    'x-auth-token': '{{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}}/invoice_line_text_template/:invoice_line_text_template_id',
  headers: {'x-auth-token': '{{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}}/invoice_line_text_template/:invoice_line_text_template_id');

req.headers({
  'x-auth-token': '{{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}}/invoice_line_text_template/:invoice_line_text_template_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"]
                                                       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}}/invoice_line_text_template/:invoice_line_text_template_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/invoice_line_text_template/:invoice_line_text_template_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/invoice_line_text_template/:invoice_line_text_template_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoice_line_text_template/:invoice_line_text_template_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")! 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()
POST Edit an invoice line text template
{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id
HEADERS

X-Auth-Token
{{apiKey}}
BODY multipartForm

Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id" {:headers {:x-auth-token "{{apiKey}}"}
                                                                                                      :multipart [{:name "html"
                                                                                                                   :content ""} {:name "image"
                                                                                                                   :content ""}]})
require "http/client"

url = "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "multipart/form-data; boundary=---011000010111000001101001"
}
reqBody = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_text_template/:invoice_line_text_template_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new MultipartFormDataContent
    {
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "html",
                }
            }
        },
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "image",
                }
            }
        },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001");
request.AddParameter("multipart/form-data; boundary=---011000010111000001101001", "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_text_template/:invoice_line_text_template_id"

	payload := strings.NewReader("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/invoice_line_text_template/:invoice_line_text_template_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: multipart/form-data; boundary=---011000010111000001101001
Host: example.com
Content-Length: 194

-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .setBody("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_text_template/:invoice_line_text_template_id"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
    .method("POST", HttpRequest.BodyPublishers.ofString("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");
Request request = new Request.Builder()
  .url("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .body("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
  .asString();
const data = new FormData();
data.append('html', '');
data.append('image', '');

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const form = new FormData();
form.append('html', '');
form.append('image', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id',
  headers: {
    'x-auth-token': '{{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}}/invoice_line_text_template/:invoice_line_text_template_id';
const form = new FormData();
form.append('html', '');
form.append('image', '');

const options = {method: 'POST', headers: {'x-auth-token': '{{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('html', '');
form.append('image', '');

const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id',
  method: 'POST',
  headers: {
    'x-auth-token': '{{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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
val request = Request.Builder()
  .url("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")
  .post(body)
  .addHeader("x-auth-token", "{{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/invoice_line_text_template/:invoice_line_text_template_id',
  headers: {
    'x-auth-token': '{{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="html"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="image"\r\n\r\n\r\n-----011000010111000001101001--\r\n');
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  formData: {html: '', image: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id');

req.headers({
  'x-auth-token': '{{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}}/invoice_line_text_template/:invoice_line_text_template_id',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  data: '-----011000010111000001101001\r\nContent-Disposition: form-data; name="html"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="image"\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('html', '');
formData.append('image', '');

const url = '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id';
const options = {method: 'POST', headers: {'x-auth-token': '{{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 = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"multipart/form-data; boundary=---011000010111000001101001" };
NSArray *parameters = @[ @{ @"name": @"html", @"value": @"" },
                         @{ @"name": @"image", @"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}}/invoice_line_text_template/:invoice_line_text_template_id"]
                                                       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}}/invoice_line_text_template/:invoice_line_text_template_id" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "multipart/form-data; boundary=---011000010111000001101001");
] in
let body = Cohttp_lwt_body.of_string "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_text_template/:invoice_line_text_template_id",
  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=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n",
  CURLOPT_HTTPHEADER => [
    "content-type: multipart/form-data; boundary=---011000010111000001101001",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id', [
  'headers' => [
    'content-type' => 'multipart/form-data; boundary=---011000010111000001101001',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'multipart/form-data; boundary=---011000010111000001101001'
]);

$request->setBody('-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
');

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
addForm(null, null);

$request->setRequestUrl('{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "multipart/form-data; boundary=---011000010111000001101001"
}

conn.request("POST", "/baseUrl/invoice_line_text_template/:invoice_line_text_template_id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "multipart/form-data; boundary=---011000010111000001101001"
}

response = requests.post(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"

payload <- "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

encode <- "multipart"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("multipart/form-data"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'multipart/form-data; boundary=---011000010111000001101001'
request.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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/invoice_line_text_template/:invoice_line_text_template_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"html\"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/invoice_line_text_template/:invoice_line_text_template_id";

    let form = reqwest::multipart::Form::new()
        .text("html", "")
        .text("image", "");
    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoice_line_text_template/:invoice_line_text_template_id \
  --header 'content-type: multipart/form-data' \
  --header 'x-auth-token: {{apiKey}}' \
  --form html= \
  --form image=
echo '-----011000010111000001101001
Content-Disposition: form-data; name="html"


-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
' |  \
  http POST {{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id \
  content-type:'multipart/form-data; boundary=---011000010111000001101001' \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: multipart/form-data; boundary=---011000010111000001101001' \
  --body-data '-----011000010111000001101001\r\nContent-Disposition: form-data; name="html"\r\n\r\n\r\n-----011000010111000001101001\r\nContent-Disposition: form-data; name="image"\r\n\r\n\r\n-----011000010111000001101001--\r\n' \
  --output-document \
  - {{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "multipart/form-data; boundary=---011000010111000001101001"
]
let parameters = [
  [
    "name": "html",
    "value": ""
  ],
  [
    "name": "image",
    "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}}/invoice_line_text_template/:invoice_line_text_template_id")! 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 a list of invoice line text templates
{{baseUrl}}/invoice_line_text_template
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoice_line_text_template");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/invoice_line_text_template" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/invoice_line_text_template"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/invoice_line_text_template"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoice_line_text_template");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoice_line_text_template"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/invoice_line_text_template HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/invoice_line_text_template")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoice_line_text_template"))
    .header("x-auth-token", "{{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}}/invoice_line_text_template")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/invoice_line_text_template")
  .header("x-auth-token", "{{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}}/invoice_line_text_template');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/invoice_line_text_template',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoice_line_text_template';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/invoice_line_text_template',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoice_line_text_template")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoice_line_text_template',
  headers: {
    'x-auth-token': '{{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}}/invoice_line_text_template',
  headers: {'x-auth-token': '{{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}}/invoice_line_text_template');

req.headers({
  'x-auth-token': '{{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}}/invoice_line_text_template',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoice_line_text_template';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoice_line_text_template"]
                                                       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}}/invoice_line_text_template" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoice_line_text_template",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/invoice_line_text_template', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoice_line_text_template');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoice_line_text_template');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoice_line_text_template' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoice_line_text_template' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/invoice_line_text_template", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoice_line_text_template"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoice_line_text_template"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoice_line_text_template")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/invoice_line_text_template') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoice_line_text_template";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoice_line_text_template \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/invoice_line_text_template \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/invoice_line_text_template
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoice_line_text_template")! 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 a single invoice line text template
{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/invoice_line_text_template/:invoice_line_text_template_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/invoice_line_text_template/:invoice_line_text_template_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"))
    .header("x-auth-token", "{{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}}/invoice_line_text_template/:invoice_line_text_template_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")
  .header("x-auth-token", "{{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}}/invoice_line_text_template/:invoice_line_text_template_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/invoice_line_text_template/:invoice_line_text_template_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoice_line_text_template/:invoice_line_text_template_id',
  headers: {
    'x-auth-token': '{{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}}/invoice_line_text_template/:invoice_line_text_template_id',
  headers: {'x-auth-token': '{{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}}/invoice_line_text_template/:invoice_line_text_template_id');

req.headers({
  'x-auth-token': '{{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}}/invoice_line_text_template/:invoice_line_text_template_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"]
                                                       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}}/invoice_line_text_template/:invoice_line_text_template_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/invoice_line_text_template/:invoice_line_text_template_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/invoice_line_text_template/:invoice_line_text_template_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoice_line_text_template/:invoice_line_text_template_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoice_line_text_template/:invoice_line_text_template_id")! 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 invoice
{{baseUrl}}/invoices
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "contact_id": "",
  "created_or_modified_gte": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/invoices" {:headers {:x-auth-token "{{apiKey}}"}
                                                     :content-type :json
                                                     :form-params {:contact_id ""
                                                                   :created_or_modified_gte ""
                                                                   :date_from ""
                                                                   :date_to ""
                                                                   :erp_id ""
                                                                   :erp_payment_term_id ""
                                                                   :invoice_number 0
                                                                   :is_draft false
                                                                   :is_locked false
                                                                   :is_offer false
                                                                   :issued_date ""
                                                                   :message ""
                                                                   :offer_number 0
                                                                   :payment_due_date ""
                                                                   :payment_term_id ""
                                                                   :project_id ""
                                                                   :reference ""
                                                                   :vat_percent 0}})
require "http/client"

url = "{{baseUrl}}/invoices"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\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}}/invoices"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\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}}/invoices");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices"

	payload := strings.NewReader("{\n  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/invoices HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 392

{
  "contact_id": "",
  "created_or_modified_gte": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/invoices")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\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  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/invoices")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/invoices")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}")
  .asString();
const data = JSON.stringify({
  contact_id: '',
  created_or_modified_gte: '',
  date_from: '',
  date_to: '',
  erp_id: '',
  erp_payment_term_id: '',
  invoice_number: 0,
  is_draft: false,
  is_locked: false,
  is_offer: false,
  issued_date: '',
  message: '',
  offer_number: 0,
  payment_due_date: '',
  payment_term_id: '',
  project_id: '',
  reference: '',
  vat_percent: 0
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/invoices');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoices',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    contact_id: '',
    created_or_modified_gte: '',
    date_from: '',
    date_to: '',
    erp_id: '',
    erp_payment_term_id: '',
    invoice_number: 0,
    is_draft: false,
    is_locked: false,
    is_offer: false,
    issued_date: '',
    message: '',
    offer_number: 0,
    payment_due_date: '',
    payment_term_id: '',
    project_id: '',
    reference: '',
    vat_percent: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"contact_id":"","created_or_modified_gte":"","date_from":"","date_to":"","erp_id":"","erp_payment_term_id":"","invoice_number":0,"is_draft":false,"is_locked":false,"is_offer":false,"issued_date":"","message":"","offer_number":0,"payment_due_date":"","payment_term_id":"","project_id":"","reference":"","vat_percent":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}}/invoices',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "contact_id": "",\n  "created_or_modified_gte": "",\n  "date_from": "",\n  "date_to": "",\n  "erp_id": "",\n  "erp_payment_term_id": "",\n  "invoice_number": 0,\n  "is_draft": false,\n  "is_locked": false,\n  "is_offer": false,\n  "issued_date": "",\n  "message": "",\n  "offer_number": 0,\n  "payment_due_date": "",\n  "payment_term_id": "",\n  "project_id": "",\n  "reference": "",\n  "vat_percent": 0\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/invoices")
  .post(body)
  .addHeader("x-auth-token", "{{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/invoices',
  headers: {
    'x-auth-token': '{{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({
  contact_id: '',
  created_or_modified_gte: '',
  date_from: '',
  date_to: '',
  erp_id: '',
  erp_payment_term_id: '',
  invoice_number: 0,
  is_draft: false,
  is_locked: false,
  is_offer: false,
  issued_date: '',
  message: '',
  offer_number: 0,
  payment_due_date: '',
  payment_term_id: '',
  project_id: '',
  reference: '',
  vat_percent: 0
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoices',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    contact_id: '',
    created_or_modified_gte: '',
    date_from: '',
    date_to: '',
    erp_id: '',
    erp_payment_term_id: '',
    invoice_number: 0,
    is_draft: false,
    is_locked: false,
    is_offer: false,
    issued_date: '',
    message: '',
    offer_number: 0,
    payment_due_date: '',
    payment_term_id: '',
    project_id: '',
    reference: '',
    vat_percent: 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('POST', '{{baseUrl}}/invoices');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  contact_id: '',
  created_or_modified_gte: '',
  date_from: '',
  date_to: '',
  erp_id: '',
  erp_payment_term_id: '',
  invoice_number: 0,
  is_draft: false,
  is_locked: false,
  is_offer: false,
  issued_date: '',
  message: '',
  offer_number: 0,
  payment_due_date: '',
  payment_term_id: '',
  project_id: '',
  reference: '',
  vat_percent: 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: 'POST',
  url: '{{baseUrl}}/invoices',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    contact_id: '',
    created_or_modified_gte: '',
    date_from: '',
    date_to: '',
    erp_id: '',
    erp_payment_term_id: '',
    invoice_number: 0,
    is_draft: false,
    is_locked: false,
    is_offer: false,
    issued_date: '',
    message: '',
    offer_number: 0,
    payment_due_date: '',
    payment_term_id: '',
    project_id: '',
    reference: '',
    vat_percent: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoices';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"contact_id":"","created_or_modified_gte":"","date_from":"","date_to":"","erp_id":"","erp_payment_term_id":"","invoice_number":0,"is_draft":false,"is_locked":false,"is_offer":false,"issued_date":"","message":"","offer_number":0,"payment_due_date":"","payment_term_id":"","project_id":"","reference":"","vat_percent":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"contact_id": @"",
                              @"created_or_modified_gte": @"",
                              @"date_from": @"",
                              @"date_to": @"",
                              @"erp_id": @"",
                              @"erp_payment_term_id": @"",
                              @"invoice_number": @0,
                              @"is_draft": @NO,
                              @"is_locked": @NO,
                              @"is_offer": @NO,
                              @"issued_date": @"",
                              @"message": @"",
                              @"offer_number": @0,
                              @"payment_due_date": @"",
                              @"payment_term_id": @"",
                              @"project_id": @"",
                              @"reference": @"",
                              @"vat_percent": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoices"]
                                                       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}}/invoices" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices",
  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([
    'contact_id' => '',
    'created_or_modified_gte' => '',
    'date_from' => '',
    'date_to' => '',
    'erp_id' => '',
    'erp_payment_term_id' => '',
    'invoice_number' => 0,
    'is_draft' => null,
    'is_locked' => null,
    'is_offer' => null,
    'issued_date' => '',
    'message' => '',
    'offer_number' => 0,
    'payment_due_date' => '',
    'payment_term_id' => '',
    'project_id' => '',
    'reference' => '',
    'vat_percent' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/invoices', [
  'body' => '{
  "contact_id": "",
  "created_or_modified_gte": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoices');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'contact_id' => '',
  'created_or_modified_gte' => '',
  'date_from' => '',
  'date_to' => '',
  'erp_id' => '',
  'erp_payment_term_id' => '',
  'invoice_number' => 0,
  'is_draft' => null,
  'is_locked' => null,
  'is_offer' => null,
  'issued_date' => '',
  'message' => '',
  'offer_number' => 0,
  'payment_due_date' => '',
  'payment_term_id' => '',
  'project_id' => '',
  'reference' => '',
  'vat_percent' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'contact_id' => '',
  'created_or_modified_gte' => '',
  'date_from' => '',
  'date_to' => '',
  'erp_id' => '',
  'erp_payment_term_id' => '',
  'invoice_number' => 0,
  'is_draft' => null,
  'is_locked' => null,
  'is_offer' => null,
  'issued_date' => '',
  'message' => '',
  'offer_number' => 0,
  'payment_due_date' => '',
  'payment_term_id' => '',
  'project_id' => '',
  'reference' => '',
  'vat_percent' => 0
]));
$request->setRequestUrl('{{baseUrl}}/invoices');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "contact_id": "",
  "created_or_modified_gte": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "contact_id": "",
  "created_or_modified_gte": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/invoices", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices"

payload = {
    "contact_id": "",
    "created_or_modified_gte": "",
    "date_from": "",
    "date_to": "",
    "erp_id": "",
    "erp_payment_term_id": "",
    "invoice_number": 0,
    "is_draft": False,
    "is_locked": False,
    "is_offer": False,
    "issued_date": "",
    "message": "",
    "offer_number": 0,
    "payment_due_date": "",
    "payment_term_id": "",
    "project_id": "",
    "reference": "",
    "vat_percent": 0
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices"

payload <- "{\n  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\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/invoices') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"contact_id\": \"\",\n  \"created_or_modified_gte\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoices";

    let payload = json!({
        "contact_id": "",
        "created_or_modified_gte": "",
        "date_from": "",
        "date_to": "",
        "erp_id": "",
        "erp_payment_term_id": "",
        "invoice_number": 0,
        "is_draft": false,
        "is_locked": false,
        "is_offer": false,
        "issued_date": "",
        "message": "",
        "offer_number": 0,
        "payment_due_date": "",
        "payment_term_id": "",
        "project_id": "",
        "reference": "",
        "vat_percent": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoices \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "contact_id": "",
  "created_or_modified_gte": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
}'
echo '{
  "contact_id": "",
  "created_or_modified_gte": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
}' |  \
  http POST {{baseUrl}}/invoices \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "contact_id": "",\n  "created_or_modified_gte": "",\n  "date_from": "",\n  "date_to": "",\n  "erp_id": "",\n  "erp_payment_term_id": "",\n  "invoice_number": 0,\n  "is_draft": false,\n  "is_locked": false,\n  "is_offer": false,\n  "issued_date": "",\n  "message": "",\n  "offer_number": 0,\n  "payment_due_date": "",\n  "payment_term_id": "",\n  "project_id": "",\n  "reference": "",\n  "vat_percent": 0\n}' \
  --output-document \
  - {{baseUrl}}/invoices
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "contact_id": "",
  "created_or_modified_gte": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices")! 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 Bulk delete invoices
{{baseUrl}}/invoices/bulkDelete
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices/bulkDelete");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/invoices/bulkDelete" {:headers {:x-auth-token "{{apiKey}}"}
                                                                  :content-type :json
                                                                  :form-params {:id []}})
require "http/client"

url = "{{baseUrl}}/invoices/bulkDelete"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": []\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}}/invoices/bulkDelete"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id\": []\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}}/invoices/bulkDelete");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices/bulkDelete"

	payload := strings.NewReader("{\n  \"id\": []\n}")

	req, _ := http.NewRequest("DELETE", url, payload)

	req.Header.Add("x-auth-token", "{{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/invoices/bulkDelete HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/invoices/bulkDelete")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices/bulkDelete"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"id\": []\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\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/invoices/bulkDelete")
  .delete(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/invoices/bulkDelete")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/invoices/bulkDelete');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/invoices/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/invoices/bulkDelete',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/invoices/bulkDelete")
  .delete(body)
  .addHeader("x-auth-token", "{{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/invoices/bulkDelete',
  headers: {
    'x-auth-token': '{{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: []}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/invoices/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {id: []},
  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}}/invoices/bulkDelete');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: []
});

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}}/invoices/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoices/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoices/bulkDelete"]
                                                       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}}/invoices/bulkDelete" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": []\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices/bulkDelete",
  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([
    'id' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/invoices/bulkDelete', [
  'body' => '{
  "id": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoices/bulkDelete');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/invoices/bulkDelete');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": []\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("DELETE", "/baseUrl/invoices/bulkDelete", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices/bulkDelete"

payload = { "id": [] }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices/bulkDelete"

payload <- "{\n  \"id\": []\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices/bulkDelete")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/invoices/bulkDelete') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"id\": []\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}}/invoices/bulkDelete";

    let payload = json!({"id": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoices/bulkDelete \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http DELETE {{baseUrl}}/invoices/bulkDelete \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/invoices/bulkDelete
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices/bulkDelete")! 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 Create a copy of an invoice
{{baseUrl}}/invoices/:invoice_id/copy
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

invoice_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices/:invoice_id/copy");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/invoices/:invoice_id/copy" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/invoices/:invoice_id/copy"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
}

response = HTTP::Client.post url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/invoices/:invoice_id/copy"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoices/:invoice_id/copy");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices/:invoice_id/copy"

	req, _ := http.NewRequest("POST", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/invoices/:invoice_id/copy HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/invoices/:invoice_id/copy")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices/:invoice_id/copy"))
    .header("x-auth-token", "{{apiKey}}")
    .method("POST", 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}}/invoices/:invoice_id/copy")
  .post(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/invoices/:invoice_id/copy")
  .header("x-auth-token", "{{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('POST', '{{baseUrl}}/invoices/:invoice_id/copy');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoices/:invoice_id/copy',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices/:invoice_id/copy';
const options = {method: 'POST', headers: {'x-auth-token': '{{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}}/invoices/:invoice_id/copy',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoices/:invoice_id/copy")
  .post(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoices/:invoice_id/copy',
  headers: {
    'x-auth-token': '{{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: 'POST',
  url: '{{baseUrl}}/invoices/:invoice_id/copy',
  headers: {'x-auth-token': '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/invoices/:invoice_id/copy');

req.headers({
  'x-auth-token': '{{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: 'POST',
  url: '{{baseUrl}}/invoices/:invoice_id/copy',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoices/:invoice_id/copy';
const options = {method: 'POST', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoices/:invoice_id/copy"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[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}}/invoices/:invoice_id/copy" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices/:invoice_id/copy",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/invoices/:invoice_id/copy', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoices/:invoice_id/copy');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoices/:invoice_id/copy');
$request->setRequestMethod('POST');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices/:invoice_id/copy' -Method POST -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices/:invoice_id/copy' -Method POST -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("POST", "/baseUrl/invoices/:invoice_id/copy", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices/:invoice_id/copy"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.post(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices/:invoice_id/copy"

response <- VERB("POST", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices/:invoice_id/copy")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/invoices/:invoice_id/copy') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoices/:invoice_id/copy";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/invoices/:invoice_id/copy \
  --header 'x-auth-token: {{apiKey}}'
http POST {{baseUrl}}/invoices/:invoice_id/copy \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/invoices/:invoice_id/copy
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices/:invoice_id/copy")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
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 Creates an invoice file containing the project's pdf overview
{{baseUrl}}/invoices/:invoice_id/linkProjectPdf
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

invoice_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices/:invoice_id/linkProjectPdf");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/invoices/:invoice_id/linkProjectPdf" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/invoices/:invoice_id/linkProjectPdf"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
}

response = HTTP::Client.post url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/invoices/:invoice_id/linkProjectPdf"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoices/:invoice_id/linkProjectPdf");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices/:invoice_id/linkProjectPdf"

	req, _ := http.NewRequest("POST", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/invoices/:invoice_id/linkProjectPdf HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/invoices/:invoice_id/linkProjectPdf")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices/:invoice_id/linkProjectPdf"))
    .header("x-auth-token", "{{apiKey}}")
    .method("POST", 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}}/invoices/:invoice_id/linkProjectPdf")
  .post(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/invoices/:invoice_id/linkProjectPdf")
  .header("x-auth-token", "{{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('POST', '{{baseUrl}}/invoices/:invoice_id/linkProjectPdf');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoices/:invoice_id/linkProjectPdf',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices/:invoice_id/linkProjectPdf';
const options = {method: 'POST', headers: {'x-auth-token': '{{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}}/invoices/:invoice_id/linkProjectPdf',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoices/:invoice_id/linkProjectPdf")
  .post(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoices/:invoice_id/linkProjectPdf',
  headers: {
    'x-auth-token': '{{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: 'POST',
  url: '{{baseUrl}}/invoices/:invoice_id/linkProjectPdf',
  headers: {'x-auth-token': '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/invoices/:invoice_id/linkProjectPdf');

req.headers({
  'x-auth-token': '{{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: 'POST',
  url: '{{baseUrl}}/invoices/:invoice_id/linkProjectPdf',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoices/:invoice_id/linkProjectPdf';
const options = {method: 'POST', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoices/:invoice_id/linkProjectPdf"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[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}}/invoices/:invoice_id/linkProjectPdf" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices/:invoice_id/linkProjectPdf",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/invoices/:invoice_id/linkProjectPdf', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoices/:invoice_id/linkProjectPdf');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoices/:invoice_id/linkProjectPdf');
$request->setRequestMethod('POST');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices/:invoice_id/linkProjectPdf' -Method POST -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices/:invoice_id/linkProjectPdf' -Method POST -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("POST", "/baseUrl/invoices/:invoice_id/linkProjectPdf", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices/:invoice_id/linkProjectPdf"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.post(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices/:invoice_id/linkProjectPdf"

response <- VERB("POST", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices/:invoice_id/linkProjectPdf")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/invoices/:invoice_id/linkProjectPdf') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoices/:invoice_id/linkProjectPdf";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/invoices/:invoice_id/linkProjectPdf \
  --header 'x-auth-token: {{apiKey}}'
http POST {{baseUrl}}/invoices/:invoice_id/linkProjectPdf \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/invoices/:invoice_id/linkProjectPdf
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices/:invoice_id/linkProjectPdf")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
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 invoice
{{baseUrl}}/invoices/:invoice_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

invoice_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices/:invoice_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/invoices/:invoice_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/invoices/:invoice_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/invoices/:invoice_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoices/:invoice_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices/:invoice_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/invoices/:invoice_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/invoices/:invoice_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices/:invoice_id"))
    .header("x-auth-token", "{{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}}/invoices/:invoice_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/invoices/:invoice_id")
  .header("x-auth-token", "{{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}}/invoices/:invoice_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/invoices/:invoice_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices/:invoice_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/invoices/:invoice_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoices/:invoice_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoices/:invoice_id',
  headers: {
    'x-auth-token': '{{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}}/invoices/:invoice_id',
  headers: {'x-auth-token': '{{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}}/invoices/:invoice_id');

req.headers({
  'x-auth-token': '{{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}}/invoices/:invoice_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoices/:invoice_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoices/:invoice_id"]
                                                       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}}/invoices/:invoice_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices/:invoice_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/invoices/:invoice_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoices/:invoice_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoices/:invoice_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices/:invoice_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices/:invoice_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/invoices/:invoice_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices/:invoice_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices/:invoice_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices/:invoice_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/invoices/:invoice_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoices/:invoice_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoices/:invoice_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/invoices/:invoice_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/invoices/:invoice_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices/:invoice_id")! 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()
POST Deletes the linked project overview pdf
{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

invoice_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
}

response = HTTP::Client.post url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf"

	req, _ := http.NewRequest("POST", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/invoices/:invoice_id/unlinkProjectPdf HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf"))
    .header("x-auth-token", "{{apiKey}}")
    .method("POST", 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}}/invoices/:invoice_id/unlinkProjectPdf")
  .post(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf")
  .header("x-auth-token", "{{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('POST', '{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf';
const options = {method: 'POST', headers: {'x-auth-token': '{{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}}/invoices/:invoice_id/unlinkProjectPdf',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf")
  .post(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoices/:invoice_id/unlinkProjectPdf',
  headers: {
    'x-auth-token': '{{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: 'POST',
  url: '{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf',
  headers: {'x-auth-token': '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf');

req.headers({
  'x-auth-token': '{{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: 'POST',
  url: '{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf';
const options = {method: 'POST', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[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}}/invoices/:invoice_id/unlinkProjectPdf" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf');
$request->setRequestMethod('POST');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf' -Method POST -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf' -Method POST -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("POST", "/baseUrl/invoices/:invoice_id/unlinkProjectPdf", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.post(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf"

response <- VERB("POST", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/invoices/:invoice_id/unlinkProjectPdf') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf \
  --header 'x-auth-token: {{apiKey}}'
http POST {{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices/:invoice_id/unlinkProjectPdf")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
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 Edit invoice
{{baseUrl}}/invoices/:invoice_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

invoice_id
BODY json

{
  "contact_id": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices/:invoice_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/invoices/:invoice_id" {:headers {:x-auth-token "{{apiKey}}"}
                                                                :content-type :json
                                                                :form-params {:contact_id ""
                                                                              :date_from ""
                                                                              :date_to ""
                                                                              :erp_id ""
                                                                              :erp_payment_term_id ""
                                                                              :invoice_number 0
                                                                              :is_draft false
                                                                              :is_locked false
                                                                              :is_offer false
                                                                              :issued_date ""
                                                                              :message ""
                                                                              :offer_number 0
                                                                              :payment_due_date ""
                                                                              :payment_term_id ""
                                                                              :project_id ""
                                                                              :reference ""
                                                                              :vat_percent 0}})
require "http/client"

url = "{{baseUrl}}/invoices/:invoice_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\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}}/invoices/:invoice_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\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}}/invoices/:invoice_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices/:invoice_id"

	payload := strings.NewReader("{\n  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("x-auth-token", "{{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/invoices/:invoice_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 359

{
  "contact_id": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/invoices/:invoice_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices/:invoice_id"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\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  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/invoices/:invoice_id")
  .put(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/invoices/:invoice_id")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}")
  .asString();
const data = JSON.stringify({
  contact_id: '',
  date_from: '',
  date_to: '',
  erp_id: '',
  erp_payment_term_id: '',
  invoice_number: 0,
  is_draft: false,
  is_locked: false,
  is_offer: false,
  issued_date: '',
  message: '',
  offer_number: 0,
  payment_due_date: '',
  payment_term_id: '',
  project_id: '',
  reference: '',
  vat_percent: 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}}/invoices/:invoice_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/invoices/:invoice_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    contact_id: '',
    date_from: '',
    date_to: '',
    erp_id: '',
    erp_payment_term_id: '',
    invoice_number: 0,
    is_draft: false,
    is_locked: false,
    is_offer: false,
    issued_date: '',
    message: '',
    offer_number: 0,
    payment_due_date: '',
    payment_term_id: '',
    project_id: '',
    reference: '',
    vat_percent: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices/:invoice_id';
const options = {
  method: 'PUT',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"contact_id":"","date_from":"","date_to":"","erp_id":"","erp_payment_term_id":"","invoice_number":0,"is_draft":false,"is_locked":false,"is_offer":false,"issued_date":"","message":"","offer_number":0,"payment_due_date":"","payment_term_id":"","project_id":"","reference":"","vat_percent":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}}/invoices/:invoice_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "contact_id": "",\n  "date_from": "",\n  "date_to": "",\n  "erp_id": "",\n  "erp_payment_term_id": "",\n  "invoice_number": 0,\n  "is_draft": false,\n  "is_locked": false,\n  "is_offer": false,\n  "issued_date": "",\n  "message": "",\n  "offer_number": 0,\n  "payment_due_date": "",\n  "payment_term_id": "",\n  "project_id": "",\n  "reference": "",\n  "vat_percent": 0\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/invoices/:invoice_id")
  .put(body)
  .addHeader("x-auth-token", "{{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/invoices/:invoice_id',
  headers: {
    'x-auth-token': '{{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({
  contact_id: '',
  date_from: '',
  date_to: '',
  erp_id: '',
  erp_payment_term_id: '',
  invoice_number: 0,
  is_draft: false,
  is_locked: false,
  is_offer: false,
  issued_date: '',
  message: '',
  offer_number: 0,
  payment_due_date: '',
  payment_term_id: '',
  project_id: '',
  reference: '',
  vat_percent: 0
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/invoices/:invoice_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    contact_id: '',
    date_from: '',
    date_to: '',
    erp_id: '',
    erp_payment_term_id: '',
    invoice_number: 0,
    is_draft: false,
    is_locked: false,
    is_offer: false,
    issued_date: '',
    message: '',
    offer_number: 0,
    payment_due_date: '',
    payment_term_id: '',
    project_id: '',
    reference: '',
    vat_percent: 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}}/invoices/:invoice_id');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  contact_id: '',
  date_from: '',
  date_to: '',
  erp_id: '',
  erp_payment_term_id: '',
  invoice_number: 0,
  is_draft: false,
  is_locked: false,
  is_offer: false,
  issued_date: '',
  message: '',
  offer_number: 0,
  payment_due_date: '',
  payment_term_id: '',
  project_id: '',
  reference: '',
  vat_percent: 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}}/invoices/:invoice_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    contact_id: '',
    date_from: '',
    date_to: '',
    erp_id: '',
    erp_payment_term_id: '',
    invoice_number: 0,
    is_draft: false,
    is_locked: false,
    is_offer: false,
    issued_date: '',
    message: '',
    offer_number: 0,
    payment_due_date: '',
    payment_term_id: '',
    project_id: '',
    reference: '',
    vat_percent: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoices/:invoice_id';
const options = {
  method: 'PUT',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"contact_id":"","date_from":"","date_to":"","erp_id":"","erp_payment_term_id":"","invoice_number":0,"is_draft":false,"is_locked":false,"is_offer":false,"issued_date":"","message":"","offer_number":0,"payment_due_date":"","payment_term_id":"","project_id":"","reference":"","vat_percent":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"contact_id": @"",
                              @"date_from": @"",
                              @"date_to": @"",
                              @"erp_id": @"",
                              @"erp_payment_term_id": @"",
                              @"invoice_number": @0,
                              @"is_draft": @NO,
                              @"is_locked": @NO,
                              @"is_offer": @NO,
                              @"issued_date": @"",
                              @"message": @"",
                              @"offer_number": @0,
                              @"payment_due_date": @"",
                              @"payment_term_id": @"",
                              @"project_id": @"",
                              @"reference": @"",
                              @"vat_percent": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoices/:invoice_id"]
                                                       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}}/invoices/:invoice_id" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices/:invoice_id",
  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([
    'contact_id' => '',
    'date_from' => '',
    'date_to' => '',
    'erp_id' => '',
    'erp_payment_term_id' => '',
    'invoice_number' => 0,
    'is_draft' => null,
    'is_locked' => null,
    'is_offer' => null,
    'issued_date' => '',
    'message' => '',
    'offer_number' => 0,
    'payment_due_date' => '',
    'payment_term_id' => '',
    'project_id' => '',
    'reference' => '',
    'vat_percent' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/invoices/:invoice_id', [
  'body' => '{
  "contact_id": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoices/:invoice_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'contact_id' => '',
  'date_from' => '',
  'date_to' => '',
  'erp_id' => '',
  'erp_payment_term_id' => '',
  'invoice_number' => 0,
  'is_draft' => null,
  'is_locked' => null,
  'is_offer' => null,
  'issued_date' => '',
  'message' => '',
  'offer_number' => 0,
  'payment_due_date' => '',
  'payment_term_id' => '',
  'project_id' => '',
  'reference' => '',
  'vat_percent' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'contact_id' => '',
  'date_from' => '',
  'date_to' => '',
  'erp_id' => '',
  'erp_payment_term_id' => '',
  'invoice_number' => 0,
  'is_draft' => null,
  'is_locked' => null,
  'is_offer' => null,
  'issued_date' => '',
  'message' => '',
  'offer_number' => 0,
  'payment_due_date' => '',
  'payment_term_id' => '',
  'project_id' => '',
  'reference' => '',
  'vat_percent' => 0
]));
$request->setRequestUrl('{{baseUrl}}/invoices/:invoice_id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices/:invoice_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "contact_id": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices/:invoice_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "contact_id": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/invoices/:invoice_id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices/:invoice_id"

payload = {
    "contact_id": "",
    "date_from": "",
    "date_to": "",
    "erp_id": "",
    "erp_payment_term_id": "",
    "invoice_number": 0,
    "is_draft": False,
    "is_locked": False,
    "is_offer": False,
    "issued_date": "",
    "message": "",
    "offer_number": 0,
    "payment_due_date": "",
    "payment_term_id": "",
    "project_id": "",
    "reference": "",
    "vat_percent": 0
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices/:invoice_id"

payload <- "{\n  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices/:invoice_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\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/invoices/:invoice_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"contact_id\": \"\",\n  \"date_from\": \"\",\n  \"date_to\": \"\",\n  \"erp_id\": \"\",\n  \"erp_payment_term_id\": \"\",\n  \"invoice_number\": 0,\n  \"is_draft\": false,\n  \"is_locked\": false,\n  \"is_offer\": false,\n  \"issued_date\": \"\",\n  \"message\": \"\",\n  \"offer_number\": 0,\n  \"payment_due_date\": \"\",\n  \"payment_term_id\": \"\",\n  \"project_id\": \"\",\n  \"reference\": \"\",\n  \"vat_percent\": 0\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}}/invoices/:invoice_id";

    let payload = json!({
        "contact_id": "",
        "date_from": "",
        "date_to": "",
        "erp_id": "",
        "erp_payment_term_id": "",
        "invoice_number": 0,
        "is_draft": false,
        "is_locked": false,
        "is_offer": false,
        "issued_date": "",
        "message": "",
        "offer_number": 0,
        "payment_due_date": "",
        "payment_term_id": "",
        "project_id": "",
        "reference": "",
        "vat_percent": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoices/:invoice_id \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "contact_id": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
}'
echo '{
  "contact_id": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
}' |  \
  http PUT {{baseUrl}}/invoices/:invoice_id \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "contact_id": "",\n  "date_from": "",\n  "date_to": "",\n  "erp_id": "",\n  "erp_payment_term_id": "",\n  "invoice_number": 0,\n  "is_draft": false,\n  "is_locked": false,\n  "is_offer": false,\n  "issued_date": "",\n  "message": "",\n  "offer_number": 0,\n  "payment_due_date": "",\n  "payment_term_id": "",\n  "project_id": "",\n  "reference": "",\n  "vat_percent": 0\n}' \
  --output-document \
  - {{baseUrl}}/invoices/:invoice_id
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "contact_id": "",
  "date_from": "",
  "date_to": "",
  "erp_id": "",
  "erp_payment_term_id": "",
  "invoice_number": 0,
  "is_draft": false,
  "is_locked": false,
  "is_offer": false,
  "issued_date": "",
  "message": "",
  "offer_number": 0,
  "payment_due_date": "",
  "payment_term_id": "",
  "project_id": "",
  "reference": "",
  "vat_percent": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices/:invoice_id")! 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 VAT options
{{baseUrl}}/invoices/vatOptions
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices/vatOptions");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/invoices/vatOptions" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/invoices/vatOptions"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/invoices/vatOptions"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoices/vatOptions");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices/vatOptions"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/invoices/vatOptions HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/invoices/vatOptions")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices/vatOptions"))
    .header("x-auth-token", "{{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}}/invoices/vatOptions")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/invoices/vatOptions")
  .header("x-auth-token", "{{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}}/invoices/vatOptions');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/invoices/vatOptions',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices/vatOptions';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/invoices/vatOptions',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoices/vatOptions")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoices/vatOptions',
  headers: {
    'x-auth-token': '{{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}}/invoices/vatOptions',
  headers: {'x-auth-token': '{{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}}/invoices/vatOptions');

req.headers({
  'x-auth-token': '{{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}}/invoices/vatOptions',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoices/vatOptions';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoices/vatOptions"]
                                                       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}}/invoices/vatOptions" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices/vatOptions",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/invoices/vatOptions', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoices/vatOptions');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoices/vatOptions');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices/vatOptions' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices/vatOptions' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/invoices/vatOptions", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices/vatOptions"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices/vatOptions"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices/vatOptions")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/invoices/vatOptions') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoices/vatOptions";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoices/vatOptions \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/invoices/vatOptions \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/invoices/vatOptions
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices/vatOptions")! 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 View invoice
{{baseUrl}}/invoices/:invoice_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

invoice_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices/:invoice_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/invoices/:invoice_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/invoices/:invoice_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/invoices/:invoice_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoices/:invoice_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices/:invoice_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/invoices/:invoice_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/invoices/:invoice_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices/:invoice_id"))
    .header("x-auth-token", "{{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}}/invoices/:invoice_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/invoices/:invoice_id")
  .header("x-auth-token", "{{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}}/invoices/:invoice_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/invoices/:invoice_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices/:invoice_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/invoices/:invoice_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoices/:invoice_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoices/:invoice_id',
  headers: {
    'x-auth-token': '{{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}}/invoices/:invoice_id',
  headers: {'x-auth-token': '{{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}}/invoices/:invoice_id');

req.headers({
  'x-auth-token': '{{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}}/invoices/:invoice_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoices/:invoice_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoices/:invoice_id"]
                                                       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}}/invoices/:invoice_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices/:invoice_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/invoices/:invoice_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoices/:invoice_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoices/:invoice_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices/:invoice_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices/:invoice_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/invoices/:invoice_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices/:invoice_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices/:invoice_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices/:invoice_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/invoices/:invoice_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoices/:invoice_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoices/:invoice_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/invoices/:invoice_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/invoices/:invoice_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices/:invoice_id")! 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 View list of invoices
{{baseUrl}}/invoices
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/invoices");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/invoices" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/invoices"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/invoices"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/invoices");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/invoices"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/invoices HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/invoices")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/invoices"))
    .header("x-auth-token", "{{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}}/invoices")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/invoices")
  .header("x-auth-token", "{{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}}/invoices');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/invoices',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/invoices';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/invoices',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/invoices")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/invoices',
  headers: {
    'x-auth-token': '{{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}}/invoices',
  headers: {'x-auth-token': '{{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}}/invoices');

req.headers({
  'x-auth-token': '{{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}}/invoices',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/invoices';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/invoices"]
                                                       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}}/invoices" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/invoices",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/invoices', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/invoices');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/invoices');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/invoices' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/invoices' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/invoices", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/invoices"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/invoices"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/invoices")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/invoices') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/invoices";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/invoices \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/invoices \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/invoices
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/invoices")! 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 Edit mass message
{{baseUrl}}/mass_messages_users/:mass_messages_user_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

mass_messages_user_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/mass_messages_users/:mass_messages_user_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/mass_messages_users/:mass_messages_user_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/mass_messages_users/:mass_messages_user_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/mass_messages_users/:mass_messages_user_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/mass_messages_users/:mass_messages_user_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/mass_messages_users/:mass_messages_user_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/mass_messages_users/:mass_messages_user_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/mass_messages_users/:mass_messages_user_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/mass_messages_users/:mass_messages_user_id"))
    .header("x-auth-token", "{{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}}/mass_messages_users/:mass_messages_user_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/mass_messages_users/:mass_messages_user_id")
  .header("x-auth-token", "{{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}}/mass_messages_users/:mass_messages_user_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/mass_messages_users/:mass_messages_user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/mass_messages_users/:mass_messages_user_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/mass_messages_users/:mass_messages_user_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/mass_messages_users/:mass_messages_user_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/mass_messages_users/:mass_messages_user_id',
  headers: {
    'x-auth-token': '{{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}}/mass_messages_users/:mass_messages_user_id',
  headers: {'x-auth-token': '{{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}}/mass_messages_users/:mass_messages_user_id');

req.headers({
  'x-auth-token': '{{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}}/mass_messages_users/:mass_messages_user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/mass_messages_users/:mass_messages_user_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/mass_messages_users/:mass_messages_user_id"]
                                                       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}}/mass_messages_users/:mass_messages_user_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/mass_messages_users/:mass_messages_user_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/mass_messages_users/:mass_messages_user_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/mass_messages_users/:mass_messages_user_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/mass_messages_users/:mass_messages_user_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/mass_messages_users/:mass_messages_user_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/mass_messages_users/:mass_messages_user_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/mass_messages_users/:mass_messages_user_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/mass_messages_users/:mass_messages_user_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/mass_messages_users/:mass_messages_user_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/mass_messages_users/:mass_messages_user_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/mass_messages_users/:mass_messages_user_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/mass_messages_users/:mass_messages_user_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/mass_messages_users/:mass_messages_user_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/mass_messages_users/:mass_messages_user_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/mass_messages_users/:mass_messages_user_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/mass_messages_users/:mass_messages_user_id")! 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()
GET View list of mass messages for specific user
{{baseUrl}}/mass_messages_users
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/mass_messages_users");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/mass_messages_users" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/mass_messages_users"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/mass_messages_users"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/mass_messages_users");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/mass_messages_users"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/mass_messages_users HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/mass_messages_users")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/mass_messages_users"))
    .header("x-auth-token", "{{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}}/mass_messages_users")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/mass_messages_users")
  .header("x-auth-token", "{{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}}/mass_messages_users');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/mass_messages_users',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/mass_messages_users';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/mass_messages_users',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/mass_messages_users")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/mass_messages_users',
  headers: {
    'x-auth-token': '{{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}}/mass_messages_users',
  headers: {'x-auth-token': '{{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}}/mass_messages_users');

req.headers({
  'x-auth-token': '{{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}}/mass_messages_users',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/mass_messages_users';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/mass_messages_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}}/mass_messages_users" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/mass_messages_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 => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/mass_messages_users', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/mass_messages_users');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/mass_messages_users');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/mass_messages_users' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/mass_messages_users' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/mass_messages_users", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/mass_messages_users"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/mass_messages_users"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/mass_messages_users")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/mass_messages_users') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/mass_messages_users";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/mass_messages_users \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/mass_messages_users \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/mass_messages_users
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/mass_messages_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()
GET View mass message
{{baseUrl}}/mass_messages_users/:mass_messages_user_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

mass_messages_user_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/mass_messages_users/:mass_messages_user_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/mass_messages_users/:mass_messages_user_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/mass_messages_users/:mass_messages_user_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/mass_messages_users/:mass_messages_user_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/mass_messages_users/:mass_messages_user_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/mass_messages_users/:mass_messages_user_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/mass_messages_users/:mass_messages_user_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/mass_messages_users/:mass_messages_user_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/mass_messages_users/:mass_messages_user_id"))
    .header("x-auth-token", "{{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}}/mass_messages_users/:mass_messages_user_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/mass_messages_users/:mass_messages_user_id")
  .header("x-auth-token", "{{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}}/mass_messages_users/:mass_messages_user_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/mass_messages_users/:mass_messages_user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/mass_messages_users/:mass_messages_user_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/mass_messages_users/:mass_messages_user_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/mass_messages_users/:mass_messages_user_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/mass_messages_users/:mass_messages_user_id',
  headers: {
    'x-auth-token': '{{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}}/mass_messages_users/:mass_messages_user_id',
  headers: {'x-auth-token': '{{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}}/mass_messages_users/:mass_messages_user_id');

req.headers({
  'x-auth-token': '{{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}}/mass_messages_users/:mass_messages_user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/mass_messages_users/:mass_messages_user_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/mass_messages_users/:mass_messages_user_id"]
                                                       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}}/mass_messages_users/:mass_messages_user_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/mass_messages_users/:mass_messages_user_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/mass_messages_users/:mass_messages_user_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/mass_messages_users/:mass_messages_user_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/mass_messages_users/:mass_messages_user_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/mass_messages_users/:mass_messages_user_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/mass_messages_users/:mass_messages_user_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/mass_messages_users/:mass_messages_user_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/mass_messages_users/:mass_messages_user_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/mass_messages_users/:mass_messages_user_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/mass_messages_users/:mass_messages_user_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/mass_messages_users/:mass_messages_user_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/mass_messages_users/:mass_messages_user_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/mass_messages_users/:mass_messages_user_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/mass_messages_users/:mass_messages_user_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/mass_messages_users/:mass_messages_user_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/mass_messages_users/:mass_messages_user_id")! 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 material rental
{{baseUrl}}/materials/:material_id/rentals/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

material_id
BODY json

{
  "form_id": "",
  "from_date": "",
  "is_invoiced": "",
  "material_id": "",
  "project_id": "",
  "quantity": "",
  "to_date": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/materials/:material_id/rentals/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/materials/:material_id/rentals/" {:headers {:x-auth-token "{{apiKey}}"}
                                                                            :content-type :json
                                                                            :form-params {:form_id ""
                                                                                          :from_date ""
                                                                                          :is_invoiced ""
                                                                                          :material_id ""
                                                                                          :project_id ""
                                                                                          :quantity ""
                                                                                          :to_date ""}})
require "http/client"

url = "{{baseUrl}}/materials/:material_id/rentals/"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\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}}/materials/:material_id/rentals/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\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}}/materials/:material_id/rentals/");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/materials/:material_id/rentals/"

	payload := strings.NewReader("{\n  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/materials/:material_id/rentals/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 135

{
  "form_id": "",
  "from_date": "",
  "is_invoiced": "",
  "material_id": "",
  "project_id": "",
  "quantity": "",
  "to_date": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/materials/:material_id/rentals/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/materials/:material_id/rentals/"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\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  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/materials/:material_id/rentals/")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/materials/:material_id/rentals/")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  form_id: '',
  from_date: '',
  is_invoiced: '',
  material_id: '',
  project_id: '',
  quantity: '',
  to_date: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/materials/:material_id/rentals/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/materials/:material_id/rentals/',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    form_id: '',
    from_date: '',
    is_invoiced: '',
    material_id: '',
    project_id: '',
    quantity: '',
    to_date: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/materials/:material_id/rentals/';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"form_id":"","from_date":"","is_invoiced":"","material_id":"","project_id":"","quantity":"","to_date":""}'
};

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}}/materials/:material_id/rentals/',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "form_id": "",\n  "from_date": "",\n  "is_invoiced": "",\n  "material_id": "",\n  "project_id": "",\n  "quantity": "",\n  "to_date": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/materials/:material_id/rentals/")
  .post(body)
  .addHeader("x-auth-token", "{{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/materials/:material_id/rentals/',
  headers: {
    'x-auth-token': '{{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({
  form_id: '',
  from_date: '',
  is_invoiced: '',
  material_id: '',
  project_id: '',
  quantity: '',
  to_date: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/materials/:material_id/rentals/',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    form_id: '',
    from_date: '',
    is_invoiced: '',
    material_id: '',
    project_id: '',
    quantity: '',
    to_date: ''
  },
  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}}/materials/:material_id/rentals/');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  form_id: '',
  from_date: '',
  is_invoiced: '',
  material_id: '',
  project_id: '',
  quantity: '',
  to_date: ''
});

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}}/materials/:material_id/rentals/',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    form_id: '',
    from_date: '',
    is_invoiced: '',
    material_id: '',
    project_id: '',
    quantity: '',
    to_date: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/materials/:material_id/rentals/';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"form_id":"","from_date":"","is_invoiced":"","material_id":"","project_id":"","quantity":"","to_date":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"form_id": @"",
                              @"from_date": @"",
                              @"is_invoiced": @"",
                              @"material_id": @"",
                              @"project_id": @"",
                              @"quantity": @"",
                              @"to_date": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/materials/:material_id/rentals/"]
                                                       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}}/materials/:material_id/rentals/" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/materials/:material_id/rentals/",
  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([
    'form_id' => '',
    'from_date' => '',
    'is_invoiced' => '',
    'material_id' => '',
    'project_id' => '',
    'quantity' => '',
    'to_date' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/materials/:material_id/rentals/', [
  'body' => '{
  "form_id": "",
  "from_date": "",
  "is_invoiced": "",
  "material_id": "",
  "project_id": "",
  "quantity": "",
  "to_date": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/materials/:material_id/rentals/');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'form_id' => '',
  'from_date' => '',
  'is_invoiced' => '',
  'material_id' => '',
  'project_id' => '',
  'quantity' => '',
  'to_date' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'form_id' => '',
  'from_date' => '',
  'is_invoiced' => '',
  'material_id' => '',
  'project_id' => '',
  'quantity' => '',
  'to_date' => ''
]));
$request->setRequestUrl('{{baseUrl}}/materials/:material_id/rentals/');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/materials/:material_id/rentals/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "form_id": "",
  "from_date": "",
  "is_invoiced": "",
  "material_id": "",
  "project_id": "",
  "quantity": "",
  "to_date": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/materials/:material_id/rentals/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "form_id": "",
  "from_date": "",
  "is_invoiced": "",
  "material_id": "",
  "project_id": "",
  "quantity": "",
  "to_date": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/materials/:material_id/rentals/", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/materials/:material_id/rentals/"

payload = {
    "form_id": "",
    "from_date": "",
    "is_invoiced": "",
    "material_id": "",
    "project_id": "",
    "quantity": "",
    "to_date": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/materials/:material_id/rentals/"

payload <- "{\n  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/materials/:material_id/rentals/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\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/materials/:material_id/rentals/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"form_id\": \"\",\n  \"from_date\": \"\",\n  \"is_invoiced\": \"\",\n  \"material_id\": \"\",\n  \"project_id\": \"\",\n  \"quantity\": \"\",\n  \"to_date\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/materials/:material_id/rentals/";

    let payload = json!({
        "form_id": "",
        "from_date": "",
        "is_invoiced": "",
        "material_id": "",
        "project_id": "",
        "quantity": "",
        "to_date": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/materials/:material_id/rentals/ \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "form_id": "",
  "from_date": "",
  "is_invoiced": "",
  "material_id": "",
  "project_id": "",
  "quantity": "",
  "to_date": ""
}'
echo '{
  "form_id": "",
  "from_date": "",
  "is_invoiced": "",
  "material_id": "",
  "project_id": "",
  "quantity": "",
  "to_date": ""
}' |  \
  http POST {{baseUrl}}/materials/:material_id/rentals/ \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "form_id": "",\n  "from_date": "",\n  "is_invoiced": "",\n  "material_id": "",\n  "project_id": "",\n  "quantity": "",\n  "to_date": ""\n}' \
  --output-document \
  - {{baseUrl}}/materials/:material_id/rentals/
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "form_id": "",
  "from_date": "",
  "is_invoiced": "",
  "material_id": "",
  "project_id": "",
  "quantity": "",
  "to_date": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/materials/:material_id/rentals/")! 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 Checkout material rental
{{baseUrl}}/materials/:material_id/rentals/checkout/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

material_id
BODY json

{
  "form_id": "",
  "material_rental_id": "",
  "to_date": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/materials/:material_id/rentals/checkout/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/materials/:material_id/rentals/checkout/" {:headers {:x-auth-token "{{apiKey}}"}
                                                                                     :content-type :json
                                                                                     :form-params {:form_id ""
                                                                                                   :material_rental_id ""
                                                                                                   :to_date ""}})
require "http/client"

url = "{{baseUrl}}/materials/:material_id/rentals/checkout/"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\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}}/materials/:material_id/rentals/checkout/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\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}}/materials/:material_id/rentals/checkout/");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/materials/:material_id/rentals/checkout/"

	payload := strings.NewReader("{\n  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/materials/:material_id/rentals/checkout/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 64

{
  "form_id": "",
  "material_rental_id": "",
  "to_date": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/materials/:material_id/rentals/checkout/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/materials/:material_id/rentals/checkout/"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\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  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/materials/:material_id/rentals/checkout/")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/materials/:material_id/rentals/checkout/")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  form_id: '',
  material_rental_id: '',
  to_date: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/materials/:material_id/rentals/checkout/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/materials/:material_id/rentals/checkout/',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {form_id: '', material_rental_id: '', to_date: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/materials/:material_id/rentals/checkout/';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"form_id":"","material_rental_id":"","to_date":""}'
};

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}}/materials/:material_id/rentals/checkout/',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "form_id": "",\n  "material_rental_id": "",\n  "to_date": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/materials/:material_id/rentals/checkout/")
  .post(body)
  .addHeader("x-auth-token", "{{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/materials/:material_id/rentals/checkout/',
  headers: {
    'x-auth-token': '{{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({form_id: '', material_rental_id: '', to_date: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/materials/:material_id/rentals/checkout/',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {form_id: '', material_rental_id: '', to_date: ''},
  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}}/materials/:material_id/rentals/checkout/');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  form_id: '',
  material_rental_id: '',
  to_date: ''
});

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}}/materials/:material_id/rentals/checkout/',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {form_id: '', material_rental_id: '', to_date: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/materials/:material_id/rentals/checkout/';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"form_id":"","material_rental_id":"","to_date":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"form_id": @"",
                              @"material_rental_id": @"",
                              @"to_date": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/materials/:material_id/rentals/checkout/"]
                                                       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}}/materials/:material_id/rentals/checkout/" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/materials/:material_id/rentals/checkout/",
  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([
    'form_id' => '',
    'material_rental_id' => '',
    'to_date' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/materials/:material_id/rentals/checkout/', [
  'body' => '{
  "form_id": "",
  "material_rental_id": "",
  "to_date": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/materials/:material_id/rentals/checkout/');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'form_id' => '',
  'material_rental_id' => '',
  'to_date' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'form_id' => '',
  'material_rental_id' => '',
  'to_date' => ''
]));
$request->setRequestUrl('{{baseUrl}}/materials/:material_id/rentals/checkout/');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/materials/:material_id/rentals/checkout/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "form_id": "",
  "material_rental_id": "",
  "to_date": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/materials/:material_id/rentals/checkout/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "form_id": "",
  "material_rental_id": "",
  "to_date": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/materials/:material_id/rentals/checkout/", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/materials/:material_id/rentals/checkout/"

payload = {
    "form_id": "",
    "material_rental_id": "",
    "to_date": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/materials/:material_id/rentals/checkout/"

payload <- "{\n  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/materials/:material_id/rentals/checkout/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\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/materials/:material_id/rentals/checkout/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"form_id\": \"\",\n  \"material_rental_id\": \"\",\n  \"to_date\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/materials/:material_id/rentals/checkout/";

    let payload = json!({
        "form_id": "",
        "material_rental_id": "",
        "to_date": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/materials/:material_id/rentals/checkout/ \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "form_id": "",
  "material_rental_id": "",
  "to_date": ""
}'
echo '{
  "form_id": "",
  "material_rental_id": "",
  "to_date": ""
}' |  \
  http POST {{baseUrl}}/materials/:material_id/rentals/checkout/ \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "form_id": "",\n  "material_rental_id": "",\n  "to_date": ""\n}' \
  --output-document \
  - {{baseUrl}}/materials/:material_id/rentals/checkout/
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "form_id": "",
  "material_rental_id": "",
  "to_date": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/materials/:material_id/rentals/checkout/")! 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 Delete material rental
{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

material_id
material_rental_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/materials/:material_id/rentals/:material_rental_id/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/materials/:material_id/rentals/:material_rental_id/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"))
    .header("x-auth-token", "{{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}}/materials/:material_id/rentals/:material_rental_id/")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")
  .header("x-auth-token", "{{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}}/materials/:material_id/rentals/:material_rental_id/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/materials/:material_id/rentals/:material_rental_id/',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/materials/:material_id/rentals/:material_rental_id/',
  headers: {
    'x-auth-token': '{{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}}/materials/:material_id/rentals/:material_rental_id/',
  headers: {'x-auth-token': '{{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}}/materials/:material_id/rentals/:material_rental_id/');

req.headers({
  'x-auth-token': '{{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}}/materials/:material_id/rentals/:material_rental_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"]
                                                       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}}/materials/:material_id/rentals/:material_rental_id/" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/materials/:material_id/rentals/:material_rental_id/", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/materials/:material_id/rentals/:material_rental_id/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/materials/:material_id/rentals/:material_rental_id/ \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/materials/:material_id/rentals/:material_rental_id/ \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/materials/:material_id/rentals/:material_rental_id/
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")! 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()
PUT Edit material rental
{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

material_id
material_rental_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/materials/:material_id/rentals/:material_rental_id/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/materials/:material_id/rentals/:material_rental_id/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"))
    .header("x-auth-token", "{{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}}/materials/:material_id/rentals/:material_rental_id/")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")
  .header("x-auth-token", "{{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}}/materials/:material_id/rentals/:material_rental_id/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/materials/:material_id/rentals/:material_rental_id/',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/materials/:material_id/rentals/:material_rental_id/',
  headers: {
    'x-auth-token': '{{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}}/materials/:material_id/rentals/:material_rental_id/',
  headers: {'x-auth-token': '{{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}}/materials/:material_id/rentals/:material_rental_id/');

req.headers({
  'x-auth-token': '{{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}}/materials/:material_id/rentals/:material_rental_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"]
                                                       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}}/materials/:material_id/rentals/:material_rental_id/" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/materials/:material_id/rentals/:material_rental_id/", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/materials/:material_id/rentals/:material_rental_id/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/materials/:material_id/rentals/:material_rental_id/ \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/materials/:material_id/rentals/:material_rental_id/ \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/materials/:material_id/rentals/:material_rental_id/
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")! 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()
GET Show list of rentals for specific material
{{baseUrl}}/materials/:material_id/rentals/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

material_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/materials/:material_id/rentals/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/materials/:material_id/rentals/" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/materials/:material_id/rentals/"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/materials/:material_id/rentals/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/materials/:material_id/rentals/");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/materials/:material_id/rentals/"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/materials/:material_id/rentals/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/materials/:material_id/rentals/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/materials/:material_id/rentals/"))
    .header("x-auth-token", "{{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}}/materials/:material_id/rentals/")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/materials/:material_id/rentals/")
  .header("x-auth-token", "{{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}}/materials/:material_id/rentals/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/materials/:material_id/rentals/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/materials/:material_id/rentals/';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/materials/:material_id/rentals/',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/materials/:material_id/rentals/")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/materials/:material_id/rentals/',
  headers: {
    'x-auth-token': '{{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}}/materials/:material_id/rentals/',
  headers: {'x-auth-token': '{{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}}/materials/:material_id/rentals/');

req.headers({
  'x-auth-token': '{{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}}/materials/:material_id/rentals/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/materials/:material_id/rentals/';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/materials/:material_id/rentals/"]
                                                       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}}/materials/:material_id/rentals/" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/materials/:material_id/rentals/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/materials/:material_id/rentals/', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/materials/:material_id/rentals/');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/materials/:material_id/rentals/');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/materials/:material_id/rentals/' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/materials/:material_id/rentals/' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/materials/:material_id/rentals/", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/materials/:material_id/rentals/"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/materials/:material_id/rentals/"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/materials/:material_id/rentals/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/materials/:material_id/rentals/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/materials/:material_id/rentals/";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/materials/:material_id/rentals/ \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/materials/:material_id/rentals/ \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/materials/:material_id/rentals/
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/materials/:material_id/rentals/")! 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 Show rental foor materi
{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

material_id
material_rental_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/materials/:material_id/rentals/:material_rental_id/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/materials/:material_id/rentals/:material_rental_id/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"))
    .header("x-auth-token", "{{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}}/materials/:material_id/rentals/:material_rental_id/")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")
  .header("x-auth-token", "{{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}}/materials/:material_id/rentals/:material_rental_id/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/materials/:material_id/rentals/:material_rental_id/',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/materials/:material_id/rentals/:material_rental_id/',
  headers: {
    'x-auth-token': '{{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}}/materials/:material_id/rentals/:material_rental_id/',
  headers: {'x-auth-token': '{{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}}/materials/:material_id/rentals/:material_rental_id/');

req.headers({
  'x-auth-token': '{{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}}/materials/:material_id/rentals/:material_rental_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"]
                                                       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}}/materials/:material_id/rentals/:material_rental_id/" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/materials/:material_id/rentals/:material_rental_id/", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/materials/:material_id/rentals/:material_rental_id/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/materials/:material_id/rentals/:material_rental_id/ \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/materials/:material_id/rentals/:material_rental_id/ \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/materials/:material_id/rentals/:material_rental_id/
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/materials/:material_id/rentals/:material_rental_id/")! 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 material
{{baseUrl}}/materials
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "barcode": "",
  "billing_cysle": "",
  "cost_price": "",
  "description": "",
  "is_single_usage": false,
  "name": "",
  "selling_price": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/materials");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/materials" {:headers {:x-auth-token "{{apiKey}}"}
                                                      :content-type :json
                                                      :form-params {:barcode ""
                                                                    :billing_cysle ""
                                                                    :cost_price ""
                                                                    :description ""
                                                                    :is_single_usage false
                                                                    :name ""
                                                                    :selling_price ""}})
require "http/client"

url = "{{baseUrl}}/materials"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\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}}/materials"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\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}}/materials");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/materials"

	payload := strings.NewReader("{\n  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/materials HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 148

{
  "barcode": "",
  "billing_cysle": "",
  "cost_price": "",
  "description": "",
  "is_single_usage": false,
  "name": "",
  "selling_price": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/materials")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/materials"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\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  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/materials")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/materials")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  barcode: '',
  billing_cysle: '',
  cost_price: '',
  description: '',
  is_single_usage: false,
  name: '',
  selling_price: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/materials');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/materials',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    barcode: '',
    billing_cysle: '',
    cost_price: '',
    description: '',
    is_single_usage: false,
    name: '',
    selling_price: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/materials';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"barcode":"","billing_cysle":"","cost_price":"","description":"","is_single_usage":false,"name":"","selling_price":""}'
};

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}}/materials',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "barcode": "",\n  "billing_cysle": "",\n  "cost_price": "",\n  "description": "",\n  "is_single_usage": false,\n  "name": "",\n  "selling_price": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/materials")
  .post(body)
  .addHeader("x-auth-token", "{{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/materials',
  headers: {
    'x-auth-token': '{{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({
  barcode: '',
  billing_cysle: '',
  cost_price: '',
  description: '',
  is_single_usage: false,
  name: '',
  selling_price: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/materials',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    barcode: '',
    billing_cysle: '',
    cost_price: '',
    description: '',
    is_single_usage: false,
    name: '',
    selling_price: ''
  },
  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}}/materials');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  barcode: '',
  billing_cysle: '',
  cost_price: '',
  description: '',
  is_single_usage: false,
  name: '',
  selling_price: ''
});

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}}/materials',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    barcode: '',
    billing_cysle: '',
    cost_price: '',
    description: '',
    is_single_usage: false,
    name: '',
    selling_price: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/materials';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"barcode":"","billing_cysle":"","cost_price":"","description":"","is_single_usage":false,"name":"","selling_price":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"barcode": @"",
                              @"billing_cysle": @"",
                              @"cost_price": @"",
                              @"description": @"",
                              @"is_single_usage": @NO,
                              @"name": @"",
                              @"selling_price": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/materials"]
                                                       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}}/materials" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/materials",
  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([
    'barcode' => '',
    'billing_cysle' => '',
    'cost_price' => '',
    'description' => '',
    'is_single_usage' => null,
    'name' => '',
    'selling_price' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/materials', [
  'body' => '{
  "barcode": "",
  "billing_cysle": "",
  "cost_price": "",
  "description": "",
  "is_single_usage": false,
  "name": "",
  "selling_price": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/materials');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'barcode' => '',
  'billing_cysle' => '',
  'cost_price' => '',
  'description' => '',
  'is_single_usage' => null,
  'name' => '',
  'selling_price' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'barcode' => '',
  'billing_cysle' => '',
  'cost_price' => '',
  'description' => '',
  'is_single_usage' => null,
  'name' => '',
  'selling_price' => ''
]));
$request->setRequestUrl('{{baseUrl}}/materials');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/materials' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "barcode": "",
  "billing_cysle": "",
  "cost_price": "",
  "description": "",
  "is_single_usage": false,
  "name": "",
  "selling_price": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/materials' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "barcode": "",
  "billing_cysle": "",
  "cost_price": "",
  "description": "",
  "is_single_usage": false,
  "name": "",
  "selling_price": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/materials", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/materials"

payload = {
    "barcode": "",
    "billing_cysle": "",
    "cost_price": "",
    "description": "",
    "is_single_usage": False,
    "name": "",
    "selling_price": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/materials"

payload <- "{\n  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/materials")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\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/materials') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"barcode\": \"\",\n  \"billing_cysle\": \"\",\n  \"cost_price\": \"\",\n  \"description\": \"\",\n  \"is_single_usage\": false,\n  \"name\": \"\",\n  \"selling_price\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/materials";

    let payload = json!({
        "barcode": "",
        "billing_cysle": "",
        "cost_price": "",
        "description": "",
        "is_single_usage": false,
        "name": "",
        "selling_price": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/materials \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "barcode": "",
  "billing_cysle": "",
  "cost_price": "",
  "description": "",
  "is_single_usage": false,
  "name": "",
  "selling_price": ""
}'
echo '{
  "barcode": "",
  "billing_cysle": "",
  "cost_price": "",
  "description": "",
  "is_single_usage": false,
  "name": "",
  "selling_price": ""
}' |  \
  http POST {{baseUrl}}/materials \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "barcode": "",\n  "billing_cysle": "",\n  "cost_price": "",\n  "description": "",\n  "is_single_usage": false,\n  "name": "",\n  "selling_price": ""\n}' \
  --output-document \
  - {{baseUrl}}/materials
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "barcode": "",
  "billing_cysle": "",
  "cost_price": "",
  "description": "",
  "is_single_usage": false,
  "name": "",
  "selling_price": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/materials")! 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 Delete material
{{baseUrl}}/materials/:material_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

material_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/materials/:material_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/materials/:material_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/materials/:material_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/materials/:material_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/materials/:material_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/materials/:material_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/materials/:material_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/materials/:material_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/materials/:material_id"))
    .header("x-auth-token", "{{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}}/materials/:material_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/materials/:material_id")
  .header("x-auth-token", "{{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}}/materials/:material_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/materials/:material_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/materials/:material_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/materials/:material_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/materials/:material_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/materials/:material_id',
  headers: {
    'x-auth-token': '{{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}}/materials/:material_id',
  headers: {'x-auth-token': '{{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}}/materials/:material_id');

req.headers({
  'x-auth-token': '{{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}}/materials/:material_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/materials/:material_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/materials/:material_id"]
                                                       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}}/materials/:material_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/materials/:material_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/materials/:material_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/materials/:material_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/materials/:material_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/materials/:material_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/materials/:material_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/materials/:material_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/materials/:material_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/materials/:material_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/materials/:material_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/materials/:material_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/materials/:material_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/materials/:material_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/materials/:material_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/materials/:material_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/materials/:material_id")! 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()
PUT Edit material
{{baseUrl}}/materials/:material_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

material_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/materials/:material_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/materials/:material_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/materials/:material_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/materials/:material_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/materials/:material_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/materials/:material_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/materials/:material_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/materials/:material_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/materials/:material_id"))
    .header("x-auth-token", "{{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}}/materials/:material_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/materials/:material_id")
  .header("x-auth-token", "{{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}}/materials/:material_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/materials/:material_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/materials/:material_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/materials/:material_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/materials/:material_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/materials/:material_id',
  headers: {
    'x-auth-token': '{{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}}/materials/:material_id',
  headers: {'x-auth-token': '{{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}}/materials/:material_id');

req.headers({
  'x-auth-token': '{{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}}/materials/:material_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/materials/:material_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/materials/:material_id"]
                                                       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}}/materials/:material_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/materials/:material_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/materials/:material_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/materials/:material_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/materials/:material_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/materials/:material_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/materials/:material_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/materials/:material_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/materials/:material_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/materials/:material_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/materials/:material_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/materials/:material_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/materials/:material_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/materials/:material_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/materials/:material_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/materials/:material_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/materials/:material_id")! 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()
GET View list of all materials
{{baseUrl}}/materials
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/materials");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/materials" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/materials"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/materials"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/materials");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/materials"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/materials HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/materials")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/materials"))
    .header("x-auth-token", "{{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}}/materials")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/materials")
  .header("x-auth-token", "{{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}}/materials');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/materials',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/materials';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/materials',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/materials")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/materials',
  headers: {
    'x-auth-token': '{{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}}/materials',
  headers: {'x-auth-token': '{{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}}/materials');

req.headers({
  'x-auth-token': '{{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}}/materials',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/materials';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/materials"]
                                                       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}}/materials" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/materials",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/materials', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/materials');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/materials');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/materials' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/materials' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/materials", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/materials"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/materials"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/materials")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/materials') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/materials";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/materials \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/materials \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/materials
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/materials")! 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 View material
{{baseUrl}}/materials/:material_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

material_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/materials/:material_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/materials/:material_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/materials/:material_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/materials/:material_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/materials/:material_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/materials/:material_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/materials/:material_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/materials/:material_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/materials/:material_id"))
    .header("x-auth-token", "{{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}}/materials/:material_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/materials/:material_id")
  .header("x-auth-token", "{{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}}/materials/:material_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/materials/:material_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/materials/:material_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/materials/:material_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/materials/:material_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/materials/:material_id',
  headers: {
    'x-auth-token': '{{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}}/materials/:material_id',
  headers: {'x-auth-token': '{{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}}/materials/:material_id');

req.headers({
  'x-auth-token': '{{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}}/materials/:material_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/materials/:material_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/materials/:material_id"]
                                                       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}}/materials/:material_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/materials/:material_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/materials/:material_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/materials/:material_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/materials/:material_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/materials/:material_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/materials/:material_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/materials/:material_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/materials/:material_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/materials/:material_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/materials/:material_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/materials/:material_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/materials/:material_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/materials/:material_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/materials/:material_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/materials/:material_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/materials/:material_id")! 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 new offer
{{baseUrl}}/offers
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "offer_lines": [],
  "project_id": "",
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/offers");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/offers" {:headers {:x-auth-token "{{apiKey}}"}
                                                   :content-type :json
                                                   :form-params {:offer_lines []
                                                                 :project_id ""
                                                                 :status ""}})
require "http/client"

url = "{{baseUrl}}/offers"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\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}}/offers"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\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}}/offers");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/offers"

	payload := strings.NewReader("{\n  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/offers HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 59

{
  "offer_lines": [],
  "project_id": "",
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/offers")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/offers"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\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  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/offers")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/offers")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  offer_lines: [],
  project_id: '',
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/offers');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/offers',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {offer_lines: [], project_id: '', status: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/offers';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"offer_lines":[],"project_id":"","status":""}'
};

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}}/offers',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "offer_lines": [],\n  "project_id": "",\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/offers")
  .post(body)
  .addHeader("x-auth-token", "{{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/offers',
  headers: {
    'x-auth-token': '{{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({offer_lines: [], project_id: '', status: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/offers',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {offer_lines: [], project_id: '', status: ''},
  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}}/offers');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  offer_lines: [],
  project_id: '',
  status: ''
});

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}}/offers',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {offer_lines: [], project_id: '', status: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/offers';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"offer_lines":[],"project_id":"","status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"offer_lines": @[  ],
                              @"project_id": @"",
                              @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/offers"]
                                                       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}}/offers" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/offers",
  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([
    'offer_lines' => [
        
    ],
    'project_id' => '',
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/offers', [
  'body' => '{
  "offer_lines": [],
  "project_id": "",
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/offers');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'offer_lines' => [
    
  ],
  'project_id' => '',
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'offer_lines' => [
    
  ],
  'project_id' => '',
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/offers');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/offers' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "offer_lines": [],
  "project_id": "",
  "status": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/offers' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "offer_lines": [],
  "project_id": "",
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/offers", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/offers"

payload = {
    "offer_lines": [],
    "project_id": "",
    "status": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/offers"

payload <- "{\n  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/offers")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\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/offers') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"offer_lines\": [],\n  \"project_id\": \"\",\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/offers";

    let payload = json!({
        "offer_lines": (),
        "project_id": "",
        "status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/offers \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "offer_lines": [],
  "project_id": "",
  "status": ""
}'
echo '{
  "offer_lines": [],
  "project_id": "",
  "status": ""
}' |  \
  http POST {{baseUrl}}/offers \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "offer_lines": [],\n  "project_id": "",\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/offers
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "offer_lines": [],
  "project_id": "",
  "status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/offers")! 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 Delete an offer
{{baseUrl}}/offers/:offer_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

offer_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/offers/:offer_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/offers/:offer_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/offers/:offer_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/offers/:offer_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/offers/:offer_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/offers/:offer_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/offers/:offer_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/offers/:offer_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/offers/:offer_id"))
    .header("x-auth-token", "{{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}}/offers/:offer_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/offers/:offer_id")
  .header("x-auth-token", "{{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}}/offers/:offer_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/offers/:offer_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/offers/:offer_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/offers/:offer_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/offers/:offer_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/offers/:offer_id',
  headers: {
    'x-auth-token': '{{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}}/offers/:offer_id',
  headers: {'x-auth-token': '{{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}}/offers/:offer_id');

req.headers({
  'x-auth-token': '{{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}}/offers/:offer_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/offers/:offer_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/offers/:offer_id"]
                                                       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}}/offers/:offer_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/offers/:offer_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/offers/:offer_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/offers/:offer_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/offers/:offer_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/offers/:offer_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/offers/:offer_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/offers/:offer_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/offers/:offer_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/offers/:offer_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/offers/:offer_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/offers/:offer_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/offers/:offer_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/offers/:offer_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/offers/:offer_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/offers/:offer_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/offers/:offer_id")! 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()
PUT Edit an offer
{{baseUrl}}/offers/:offer_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

offer_id
BODY formUrlEncoded

status
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/offers/:offer_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/x-www-form-urlencoded");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "status=");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/offers/:offer_id" {:headers {:x-auth-token "{{apiKey}}"}
                                                            :form-params {:status ""}})
require "http/client"

url = "{{baseUrl}}/offers/:offer_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/x-www-form-urlencoded"
}
reqBody = "status="

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}}/offers/:offer_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new FormUrlEncodedContent(new Dictionary
    {
        { "status", "" },
    }),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/offers/:offer_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/x-www-form-urlencoded");
request.AddParameter("application/x-www-form-urlencoded", "status=", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/offers/:offer_id"

	payload := strings.NewReader("status=")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("x-auth-token", "{{apiKey}}")
	req.Header.Add("content-type", "application/x-www-form-urlencoded")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/offers/:offer_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/x-www-form-urlencoded
Host: example.com
Content-Length: 7

status=
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/offers/:offer_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/x-www-form-urlencoded")
  .setBody("status=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/offers/:offer_id"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/x-www-form-urlencoded")
    .method("PUT", HttpRequest.BodyPublishers.ofString("status="))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/x-www-form-urlencoded");
RequestBody body = RequestBody.create(mediaType, "status=");
Request request = new Request.Builder()
  .url("{{baseUrl}}/offers/:offer_id")
  .put(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/x-www-form-urlencoded")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/offers/:offer_id")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/x-www-form-urlencoded")
  .body("status=")
  .asString();
const data = 'status=';

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/offers/:offer_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/x-www-form-urlencoded');

xhr.send(data);
import axios from 'axios';

const encodedParams = new URLSearchParams();
encodedParams.set('status', '');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/offers/:offer_id',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  data: encodedParams,
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/offers/:offer_id';
const options = {
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  body: new URLSearchParams({status: ''})
};

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}}/offers/:offer_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  data: {
    status: ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/x-www-form-urlencoded")
val body = RequestBody.create(mediaType, "status=")
val request = Request.Builder()
  .url("{{baseUrl}}/offers/:offer_id")
  .put(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/x-www-form-urlencoded")
  .build()

val response = client.newCall(request).execute()
const qs = require('querystring');
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/offers/:offer_id',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  }
};

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(qs.stringify({status: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/offers/:offer_id',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  form: {status: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/offers/:offer_id');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/x-www-form-urlencoded'
});

req.form({
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;
const { URLSearchParams } = require('url');

const encodedParams = new URLSearchParams();
encodedParams.set('status', '');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/offers/:offer_id',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  data: encodedParams,
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const { URLSearchParams } = require('url');
const fetch = require('node-fetch');

const encodedParams = new URLSearchParams();
encodedParams.set('status', '');

const url = '{{baseUrl}}/offers/:offer_id';
const options = {
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  body: encodedParams
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/x-www-form-urlencoded" };

NSMutableData *postData = [[NSMutableData alloc] initWithData:[@"status=" dataUsingEncoding:NSUTF8StringEncoding]];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/offers/:offer_id"]
                                                       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}}/offers/:offer_id" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/x-www-form-urlencoded");
] in
let body = Cohttp_lwt_body.of_string "status=" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/offers/:offer_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => "status=",
  CURLOPT_HTTPHEADER => [
    "content-type: application/x-www-form-urlencoded",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/offers/:offer_id', [
  'form_params' => [
    'status' => ''
  ],
  'headers' => [
    'content-type' => 'application/x-www-form-urlencoded',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/offers/:offer_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/x-www-form-urlencoded'
]);

$request->setContentType('application/x-www-form-urlencoded');
$request->setPostFields([
  'status' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(new http\QueryString([
  'status' => ''
]));

$request->setRequestUrl('{{baseUrl}}/offers/:offer_id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/x-www-form-urlencoded'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/x-www-form-urlencoded")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/offers/:offer_id' -Method PUT -Headers $headers -ContentType 'application/x-www-form-urlencoded' -Body 'status='
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/x-www-form-urlencoded")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/offers/:offer_id' -Method PUT -Headers $headers -ContentType 'application/x-www-form-urlencoded' -Body 'status='
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "status="

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/x-www-form-urlencoded"
}

conn.request("PUT", "/baseUrl/offers/:offer_id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/offers/:offer_id"

payload = { "status": "" }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/x-www-form-urlencoded"
}

response = requests.put(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/offers/:offer_id"

payload <- "status="

encode <- "form"

response <- VERB("PUT", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/x-www-form-urlencoded"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/offers/:offer_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/x-www-form-urlencoded'
request.body = "status="

response = http.request(request)
puts response.read_body
require 'faraday'

data = {
  :status => "",
}

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/x-www-form-urlencoded'}
)

response = conn.put('/baseUrl/offers/:offer_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = URI.encode_www_form(data)
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}}/offers/:offer_id";

    let payload = json!({"status": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/x-www-form-urlencoded".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .form(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/offers/:offer_id \
  --header 'content-type: application/x-www-form-urlencoded' \
  --header 'x-auth-token: {{apiKey}}' \
  --data status=
http --form PUT {{baseUrl}}/offers/:offer_id \
  content-type:application/x-www-form-urlencoded \
  x-auth-token:'{{apiKey}}' \
  status=''
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/x-www-form-urlencoded' \
  --body-data status= \
  --output-document \
  - {{baseUrl}}/offers/:offer_id
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/x-www-form-urlencoded"
]

let postData = NSMutableData(data: "status=".data(using: String.Encoding.utf8)!)

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/offers/:offer_id")! 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 View list of offers
{{baseUrl}}/offers
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/offers");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/offers" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/offers"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/offers"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/offers");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/offers"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/offers HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/offers")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/offers"))
    .header("x-auth-token", "{{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}}/offers")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/offers")
  .header("x-auth-token", "{{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}}/offers');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/offers',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/offers';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/offers',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/offers")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/offers',
  headers: {
    'x-auth-token': '{{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}}/offers',
  headers: {'x-auth-token': '{{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}}/offers');

req.headers({
  'x-auth-token': '{{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}}/offers',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/offers';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/offers"]
                                                       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}}/offers" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/offers",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/offers', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/offers');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/offers');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/offers' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/offers' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/offers", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/offers"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/offers"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/offers")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/offers') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/offers";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/offers \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/offers \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/offers
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/offers")! 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 View offer
{{baseUrl}}/offers/:offer_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

offer_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/offers/:offer_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/offers/:offer_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/offers/:offer_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/offers/:offer_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/offers/:offer_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/offers/:offer_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/offers/:offer_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/offers/:offer_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/offers/:offer_id"))
    .header("x-auth-token", "{{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}}/offers/:offer_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/offers/:offer_id")
  .header("x-auth-token", "{{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}}/offers/:offer_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/offers/:offer_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/offers/:offer_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/offers/:offer_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/offers/:offer_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/offers/:offer_id',
  headers: {
    'x-auth-token': '{{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}}/offers/:offer_id',
  headers: {'x-auth-token': '{{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}}/offers/:offer_id');

req.headers({
  'x-auth-token': '{{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}}/offers/:offer_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/offers/:offer_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/offers/:offer_id"]
                                                       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}}/offers/:offer_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/offers/:offer_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/offers/:offer_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/offers/:offer_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/offers/:offer_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/offers/:offer_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/offers/:offer_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/offers/:offer_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/offers/:offer_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/offers/:offer_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/offers/:offer_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/offers/:offer_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/offers/:offer_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/offers/:offer_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/offers/:offer_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/offers/:offer_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/offers/:offer_id")! 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 Bulk delete offer statuses
{{baseUrl}}/offer_statuses/bulkDelete
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/offer_statuses/bulkDelete");

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  \"id\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/offer_statuses/bulkDelete" {:content-type :json
                                                                        :form-params {:id []}})
require "http/client"

url = "{{baseUrl}}/offer_statuses/bulkDelete"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": []\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}}/offer_statuses/bulkDelete"),
    Content = new StringContent("{\n  \"id\": []\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}}/offer_statuses/bulkDelete");
var request = new RestRequest("", Method.Delete);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/offer_statuses/bulkDelete"

	payload := strings.NewReader("{\n  \"id\": []\n}")

	req, _ := http.NewRequest("DELETE", 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))

}
DELETE /baseUrl/offer_statuses/bulkDelete HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/offer_statuses/bulkDelete")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/offer_statuses/bulkDelete"))
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"id\": []\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\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/offer_statuses/bulkDelete")
  .delete(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/offer_statuses/bulkDelete")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/offer_statuses/bulkDelete');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/offer_statuses/bulkDelete',
  headers: {'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/offer_statuses/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/offer_statuses/bulkDelete',
  method: 'DELETE',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/offer_statuses/bulkDelete")
  .delete(body)
  .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/offer_statuses/bulkDelete',
  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({id: []}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/offer_statuses/bulkDelete',
  headers: {'content-type': 'application/json'},
  body: {id: []},
  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}}/offer_statuses/bulkDelete');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: []
});

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}}/offer_statuses/bulkDelete',
  headers: {'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/offer_statuses/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'content-type': 'application/json'},
  body: '{"id":[]}'
};

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 = @{ @"id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/offer_statuses/bulkDelete"]
                                                       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}}/offer_statuses/bulkDelete" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": []\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/offer_statuses/bulkDelete",
  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([
    'id' => [
        
    ]
  ]),
  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('DELETE', '{{baseUrl}}/offer_statuses/bulkDelete', [
  'body' => '{
  "id": []
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/offer_statuses/bulkDelete');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/offer_statuses/bulkDelete');
$request->setRequestMethod('DELETE');
$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}}/offer_statuses/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/offer_statuses/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": []\n}"

headers = { 'content-type': "application/json" }

conn.request("DELETE", "/baseUrl/offer_statuses/bulkDelete", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/offer_statuses/bulkDelete"

payload = { "id": [] }
headers = {"content-type": "application/json"}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/offer_statuses/bulkDelete"

payload <- "{\n  \"id\": []\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/offer_statuses/bulkDelete")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/offer_statuses/bulkDelete') do |req|
  req.body = "{\n  \"id\": []\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}}/offer_statuses/bulkDelete";

    let payload = json!({"id": ()});

    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("DELETE").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/offer_statuses/bulkDelete \
  --header 'content-type: application/json' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http DELETE {{baseUrl}}/offer_statuses/bulkDelete \
  content-type:application/json
wget --quiet \
  --method DELETE \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/offer_statuses/bulkDelete
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/offer_statuses/bulkDelete")! 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 Create a new offer status
{{baseUrl}}/offer_statuses
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "company_id": "",
  "description": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/offer_statuses");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/offer_statuses" {:headers {:x-auth-token "{{apiKey}}"}
                                                           :content-type :json
                                                           :form-params {:company_id ""
                                                                         :description ""
                                                                         :identifier ""
                                                                         :is_custom false
                                                                         :name ""}})
require "http/client"

url = "{{baseUrl}}/offer_statuses"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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}}/offer_statuses"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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}}/offer_statuses");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/offer_statuses"

	payload := strings.NewReader("{\n  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/offer_statuses HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 99

{
  "company_id": "",
  "description": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/offer_statuses")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/offer_statuses"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/offer_statuses")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/offer_statuses")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  company_id: '',
  description: '',
  identifier: '',
  is_custom: false,
  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}}/offer_statuses');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/offer_statuses',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {company_id: '', description: '', identifier: '', is_custom: false, name: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/offer_statuses';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"company_id":"","description":"","identifier":"","is_custom":false,"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}}/offer_statuses',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "company_id": "",\n  "description": "",\n  "identifier": "",\n  "is_custom": false,\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  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/offer_statuses")
  .post(body)
  .addHeader("x-auth-token", "{{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/offer_statuses',
  headers: {
    'x-auth-token': '{{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({company_id: '', description: '', identifier: '', is_custom: false, name: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/offer_statuses',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {company_id: '', description: '', identifier: '', is_custom: false, 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}}/offer_statuses');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  company_id: '',
  description: '',
  identifier: '',
  is_custom: false,
  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}}/offer_statuses',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {company_id: '', description: '', identifier: '', is_custom: false, name: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/offer_statuses';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"company_id":"","description":"","identifier":"","is_custom":false,"name":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"company_id": @"",
                              @"description": @"",
                              @"identifier": @"",
                              @"is_custom": @NO,
                              @"name": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/offer_statuses"]
                                                       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}}/offer_statuses" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/offer_statuses",
  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([
    'company_id' => '',
    'description' => '',
    'identifier' => '',
    'is_custom' => null,
    'name' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/offer_statuses', [
  'body' => '{
  "company_id": "",
  "description": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/offer_statuses');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'company_id' => '',
  'description' => '',
  'identifier' => '',
  'is_custom' => null,
  'name' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'company_id' => '',
  'description' => '',
  'identifier' => '',
  'is_custom' => null,
  'name' => ''
]));
$request->setRequestUrl('{{baseUrl}}/offer_statuses');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/offer_statuses' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "company_id": "",
  "description": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/offer_statuses' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "company_id": "",
  "description": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/offer_statuses", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/offer_statuses"

payload = {
    "company_id": "",
    "description": "",
    "identifier": "",
    "is_custom": False,
    "name": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/offer_statuses"

payload <- "{\n  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/offer_statuses")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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/offer_statuses') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"company_id\": \"\",\n  \"description\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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}}/offer_statuses";

    let payload = json!({
        "company_id": "",
        "description": "",
        "identifier": "",
        "is_custom": false,
        "name": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/offer_statuses \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "company_id": "",
  "description": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}'
echo '{
  "company_id": "",
  "description": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}' |  \
  http POST {{baseUrl}}/offer_statuses \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "company_id": "",\n  "description": "",\n  "identifier": "",\n  "is_custom": false,\n  "name": ""\n}' \
  --output-document \
  - {{baseUrl}}/offer_statuses
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "company_id": "",
  "description": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/offer_statuses")! 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 Delete a offer status
{{baseUrl}}/offer_statuses/:offer_status_id
QUERY PARAMS

offer_status_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/offer_statuses/:offer_status_id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/offer_statuses/:offer_status_id")
require "http/client"

url = "{{baseUrl}}/offer_statuses/:offer_status_id"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/offer_statuses/:offer_status_id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/offer_statuses/:offer_status_id");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/offer_statuses/:offer_status_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/offer_statuses/:offer_status_id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/offer_statuses/:offer_status_id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/offer_statuses/:offer_status_id"))
    .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}}/offer_statuses/:offer_status_id")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/offer_statuses/:offer_status_id")
  .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}}/offer_statuses/:offer_status_id');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/offer_statuses/:offer_status_id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/offer_statuses/:offer_status_id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/offer_statuses/:offer_status_id',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/offer_statuses/:offer_status_id")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/offer_statuses/:offer_status_id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/offer_statuses/:offer_status_id'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/offer_statuses/:offer_status_id');

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}}/offer_statuses/:offer_status_id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/offer_statuses/:offer_status_id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/offer_statuses/:offer_status_id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/offer_statuses/:offer_status_id" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/offer_statuses/:offer_status_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/offer_statuses/:offer_status_id');

echo $response->getBody();
setUrl('{{baseUrl}}/offer_statuses/:offer_status_id');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/offer_statuses/:offer_status_id');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/offer_statuses/:offer_status_id' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/offer_statuses/:offer_status_id' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/offer_statuses/:offer_status_id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/offer_statuses/:offer_status_id"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/offer_statuses/:offer_status_id"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/offer_statuses/:offer_status_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/offer_statuses/:offer_status_id') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/offer_statuses/:offer_status_id";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/offer_statuses/:offer_status_id
http DELETE {{baseUrl}}/offer_statuses/:offer_status_id
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/offer_statuses/:offer_status_id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/offer_statuses/:offer_status_id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT Edit a offer status
{{baseUrl}}/offer_statuses/:offer_status_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

offer_status_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/offer_statuses/:offer_status_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/offer_statuses/:offer_status_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/offer_statuses/:offer_status_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/offer_statuses/:offer_status_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/offer_statuses/:offer_status_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/offer_statuses/:offer_status_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/offer_statuses/:offer_status_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/offer_statuses/:offer_status_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/offer_statuses/:offer_status_id"))
    .header("x-auth-token", "{{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}}/offer_statuses/:offer_status_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/offer_statuses/:offer_status_id")
  .header("x-auth-token", "{{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}}/offer_statuses/:offer_status_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/offer_statuses/:offer_status_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/offer_statuses/:offer_status_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/offer_statuses/:offer_status_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/offer_statuses/:offer_status_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/offer_statuses/:offer_status_id',
  headers: {
    'x-auth-token': '{{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}}/offer_statuses/:offer_status_id',
  headers: {'x-auth-token': '{{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}}/offer_statuses/:offer_status_id');

req.headers({
  'x-auth-token': '{{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}}/offer_statuses/:offer_status_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/offer_statuses/:offer_status_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/offer_statuses/:offer_status_id"]
                                                       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}}/offer_statuses/:offer_status_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/offer_statuses/:offer_status_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/offer_statuses/:offer_status_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/offer_statuses/:offer_status_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/offer_statuses/:offer_status_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/offer_statuses/:offer_status_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/offer_statuses/:offer_status_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/offer_statuses/:offer_status_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/offer_statuses/:offer_status_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/offer_statuses/:offer_status_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/offer_statuses/:offer_status_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/offer_statuses/:offer_status_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/offer_statuses/:offer_status_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/offer_statuses/:offer_status_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/offer_statuses/:offer_status_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/offer_statuses/:offer_status_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/offer_statuses/:offer_status_id")! 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()
GET Get a single offer status
{{baseUrl}}/offer_statuses/:offer_status_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

offer_status_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/offer_statuses/:offer_status_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/offer_statuses/:offer_status_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/offer_statuses/:offer_status_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/offer_statuses/:offer_status_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/offer_statuses/:offer_status_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/offer_statuses/:offer_status_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/offer_statuses/:offer_status_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/offer_statuses/:offer_status_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/offer_statuses/:offer_status_id"))
    .header("x-auth-token", "{{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}}/offer_statuses/:offer_status_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/offer_statuses/:offer_status_id")
  .header("x-auth-token", "{{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}}/offer_statuses/:offer_status_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/offer_statuses/:offer_status_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/offer_statuses/:offer_status_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/offer_statuses/:offer_status_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/offer_statuses/:offer_status_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/offer_statuses/:offer_status_id',
  headers: {
    'x-auth-token': '{{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}}/offer_statuses/:offer_status_id',
  headers: {'x-auth-token': '{{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}}/offer_statuses/:offer_status_id');

req.headers({
  'x-auth-token': '{{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}}/offer_statuses/:offer_status_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/offer_statuses/:offer_status_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/offer_statuses/:offer_status_id"]
                                                       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}}/offer_statuses/:offer_status_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/offer_statuses/:offer_status_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/offer_statuses/:offer_status_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/offer_statuses/:offer_status_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/offer_statuses/:offer_status_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/offer_statuses/:offer_status_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/offer_statuses/:offer_status_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/offer_statuses/:offer_status_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/offer_statuses/:offer_status_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/offer_statuses/:offer_status_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/offer_statuses/:offer_status_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/offer_statuses/:offer_status_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/offer_statuses/:offer_status_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/offer_statuses/:offer_status_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/offer_statuses/:offer_status_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/offer_statuses/:offer_status_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/offer_statuses/:offer_status_id")! 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 list of offer statuses
{{baseUrl}}/offer_statuses
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/offer_statuses");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/offer_statuses" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/offer_statuses"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/offer_statuses"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/offer_statuses");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/offer_statuses"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/offer_statuses HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/offer_statuses")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/offer_statuses"))
    .header("x-auth-token", "{{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}}/offer_statuses")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/offer_statuses")
  .header("x-auth-token", "{{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}}/offer_statuses');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/offer_statuses',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/offer_statuses';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/offer_statuses',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/offer_statuses")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/offer_statuses',
  headers: {
    'x-auth-token': '{{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}}/offer_statuses',
  headers: {'x-auth-token': '{{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}}/offer_statuses');

req.headers({
  'x-auth-token': '{{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}}/offer_statuses',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/offer_statuses';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/offer_statuses"]
                                                       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}}/offer_statuses" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/offer_statuses",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/offer_statuses', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/offer_statuses');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/offer_statuses');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/offer_statuses' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/offer_statuses' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/offer_statuses", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/offer_statuses"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/offer_statuses"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/offer_statuses")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/offer_statuses') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/offer_statuses";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/offer_statuses \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/offer_statuses \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/offer_statuses
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/offer_statuses")! 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 Details of 1 payment term
{{baseUrl}}/payment_terms/:payment_term_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

payment_term_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/payment_terms/:payment_term_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/payment_terms/:payment_term_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/payment_terms/:payment_term_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/payment_terms/:payment_term_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/payment_terms/:payment_term_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/payment_terms/:payment_term_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/payment_terms/:payment_term_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/payment_terms/:payment_term_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/payment_terms/:payment_term_id"))
    .header("x-auth-token", "{{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}}/payment_terms/:payment_term_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/payment_terms/:payment_term_id")
  .header("x-auth-token", "{{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}}/payment_terms/:payment_term_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/payment_terms/:payment_term_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/payment_terms/:payment_term_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/payment_terms/:payment_term_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/payment_terms/:payment_term_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/payment_terms/:payment_term_id',
  headers: {
    'x-auth-token': '{{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}}/payment_terms/:payment_term_id',
  headers: {'x-auth-token': '{{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}}/payment_terms/:payment_term_id');

req.headers({
  'x-auth-token': '{{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}}/payment_terms/:payment_term_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/payment_terms/:payment_term_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/payment_terms/:payment_term_id"]
                                                       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}}/payment_terms/:payment_term_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/payment_terms/:payment_term_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/payment_terms/:payment_term_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/payment_terms/:payment_term_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/payment_terms/:payment_term_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/payment_terms/:payment_term_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/payment_terms/:payment_term_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/payment_terms/:payment_term_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/payment_terms/:payment_term_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/payment_terms/:payment_term_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/payment_terms/:payment_term_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/payment_terms/:payment_term_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/payment_terms/:payment_term_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/payment_terms/:payment_term_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/payment_terms/:payment_term_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/payment_terms/:payment_term_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/payment_terms/:payment_term_id")! 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 a list of payment terms
{{baseUrl}}/payment_terms
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/payment_terms");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/payment_terms" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/payment_terms"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/payment_terms"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/payment_terms");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/payment_terms"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/payment_terms HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/payment_terms")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/payment_terms"))
    .header("x-auth-token", "{{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}}/payment_terms")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/payment_terms")
  .header("x-auth-token", "{{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}}/payment_terms');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/payment_terms',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/payment_terms';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/payment_terms',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/payment_terms")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/payment_terms',
  headers: {
    'x-auth-token': '{{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}}/payment_terms',
  headers: {'x-auth-token': '{{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}}/payment_terms');

req.headers({
  'x-auth-token': '{{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}}/payment_terms',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/payment_terms';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/payment_terms"]
                                                       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}}/payment_terms" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/payment_terms",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/payment_terms', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/payment_terms');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/payment_terms');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/payment_terms' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/payment_terms' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/payment_terms", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/payment_terms"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/payment_terms"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/payment_terms")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/payment_terms') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/payment_terms";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/payment_terms \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/payment_terms \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/payment_terms
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/payment_terms")! 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 integration payment terms list
{{baseUrl}}/payment_terms/erp
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/payment_terms/erp");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/payment_terms/erp" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/payment_terms/erp"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/payment_terms/erp"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/payment_terms/erp");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/payment_terms/erp"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/payment_terms/erp HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/payment_terms/erp")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/payment_terms/erp"))
    .header("x-auth-token", "{{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}}/payment_terms/erp")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/payment_terms/erp")
  .header("x-auth-token", "{{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}}/payment_terms/erp');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/payment_terms/erp',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/payment_terms/erp';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/payment_terms/erp',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/payment_terms/erp")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/payment_terms/erp',
  headers: {
    'x-auth-token': '{{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}}/payment_terms/erp',
  headers: {'x-auth-token': '{{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}}/payment_terms/erp');

req.headers({
  'x-auth-token': '{{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}}/payment_terms/erp',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/payment_terms/erp';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/payment_terms/erp"]
                                                       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}}/payment_terms/erp" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/payment_terms/erp",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/payment_terms/erp', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/payment_terms/erp');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/payment_terms/erp');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/payment_terms/erp' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/payment_terms/erp' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/payment_terms/erp", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/payment_terms/erp"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/payment_terms/erp"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/payment_terms/erp")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/payment_terms/erp') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/payment_terms/erp";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/payment_terms/erp \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/payment_terms/erp \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/payment_terms/erp
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/payment_terms/erp")! 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 Details of 1 payment term type
{{baseUrl}}/payment_term_types/:payment_term_type_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

payment_term_type_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/payment_term_types/:payment_term_type_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/payment_term_types/:payment_term_type_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/payment_term_types/:payment_term_type_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/payment_term_types/:payment_term_type_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/payment_term_types/:payment_term_type_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/payment_term_types/:payment_term_type_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/payment_term_types/:payment_term_type_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/payment_term_types/:payment_term_type_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/payment_term_types/:payment_term_type_id"))
    .header("x-auth-token", "{{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}}/payment_term_types/:payment_term_type_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/payment_term_types/:payment_term_type_id")
  .header("x-auth-token", "{{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}}/payment_term_types/:payment_term_type_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/payment_term_types/:payment_term_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/payment_term_types/:payment_term_type_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/payment_term_types/:payment_term_type_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/payment_term_types/:payment_term_type_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/payment_term_types/:payment_term_type_id',
  headers: {
    'x-auth-token': '{{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}}/payment_term_types/:payment_term_type_id',
  headers: {'x-auth-token': '{{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}}/payment_term_types/:payment_term_type_id');

req.headers({
  'x-auth-token': '{{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}}/payment_term_types/:payment_term_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/payment_term_types/:payment_term_type_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/payment_term_types/:payment_term_type_id"]
                                                       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}}/payment_term_types/:payment_term_type_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/payment_term_types/:payment_term_type_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/payment_term_types/:payment_term_type_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/payment_term_types/:payment_term_type_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/payment_term_types/:payment_term_type_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/payment_term_types/:payment_term_type_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/payment_term_types/:payment_term_type_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/payment_term_types/:payment_term_type_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/payment_term_types/:payment_term_type_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/payment_term_types/:payment_term_type_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/payment_term_types/:payment_term_type_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/payment_term_types/:payment_term_type_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/payment_term_types/:payment_term_type_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/payment_term_types/:payment_term_type_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/payment_term_types/:payment_term_type_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/payment_term_types/:payment_term_type_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/payment_term_types/:payment_term_type_id")! 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 a list of payment term types
{{baseUrl}}/payment_term_types
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/payment_term_types");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/payment_term_types" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/payment_term_types"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/payment_term_types"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/payment_term_types");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/payment_term_types"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/payment_term_types HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/payment_term_types")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/payment_term_types"))
    .header("x-auth-token", "{{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}}/payment_term_types")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/payment_term_types")
  .header("x-auth-token", "{{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}}/payment_term_types');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/payment_term_types',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/payment_term_types';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/payment_term_types',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/payment_term_types")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/payment_term_types',
  headers: {
    'x-auth-token': '{{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}}/payment_term_types',
  headers: {'x-auth-token': '{{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}}/payment_term_types');

req.headers({
  'x-auth-token': '{{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}}/payment_term_types',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/payment_term_types';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/payment_term_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}}/payment_term_types" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/payment_term_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 => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/payment_term_types', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/payment_term_types');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/payment_term_types');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/payment_term_types' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/payment_term_types' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/payment_term_types", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/payment_term_types"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/payment_term_types"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/payment_term_types")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/payment_term_types') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/payment_term_types";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/payment_term_types \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/payment_term_types \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/payment_term_types
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/payment_term_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()
GET Check if API is up and API key works
{{baseUrl}}/ping
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ping");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/ping" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/ping"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/ping"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ping");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ping"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/ping HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/ping")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ping"))
    .header("x-auth-token", "{{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}}/ping")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/ping")
  .header("x-auth-token", "{{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}}/ping');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/ping',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ping';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/ping',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/ping")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/ping',
  headers: {
    'x-auth-token': '{{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}}/ping',
  headers: {'x-auth-token': '{{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}}/ping');

req.headers({
  'x-auth-token': '{{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}}/ping',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ping';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ping"]
                                                       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}}/ping" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ping",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/ping', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ping');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/ping');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/ping' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ping' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/ping", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ping"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ping"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/ping")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/ping') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ping";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/ping \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/ping \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/ping
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ping")! 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 new product
{{baseUrl}}/products
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "barcode": "",
  "buying_price": "",
  "description": "",
  "erp_id": "",
  "name": "",
  "product_number": "",
  "selling_price": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/products");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/products" {:headers {:x-auth-token "{{apiKey}}"}
                                                     :content-type :json
                                                     :form-params {:barcode ""
                                                                   :buying_price ""
                                                                   :description ""
                                                                   :erp_id ""
                                                                   :name ""
                                                                   :product_number ""
                                                                   :selling_price ""}})
require "http/client"

url = "{{baseUrl}}/products"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\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}}/products"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\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}}/products");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/products"

	payload := strings.NewReader("{\n  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/products HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 139

{
  "barcode": "",
  "buying_price": "",
  "description": "",
  "erp_id": "",
  "name": "",
  "product_number": "",
  "selling_price": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/products")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/products"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\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  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/products")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/products")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  barcode: '',
  buying_price: '',
  description: '',
  erp_id: '',
  name: '',
  product_number: '',
  selling_price: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/products');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/products',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    barcode: '',
    buying_price: '',
    description: '',
    erp_id: '',
    name: '',
    product_number: '',
    selling_price: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/products';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"barcode":"","buying_price":"","description":"","erp_id":"","name":"","product_number":"","selling_price":""}'
};

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}}/products',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "barcode": "",\n  "buying_price": "",\n  "description": "",\n  "erp_id": "",\n  "name": "",\n  "product_number": "",\n  "selling_price": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/products")
  .post(body)
  .addHeader("x-auth-token", "{{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/products',
  headers: {
    'x-auth-token': '{{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({
  barcode: '',
  buying_price: '',
  description: '',
  erp_id: '',
  name: '',
  product_number: '',
  selling_price: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/products',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    barcode: '',
    buying_price: '',
    description: '',
    erp_id: '',
    name: '',
    product_number: '',
    selling_price: ''
  },
  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}}/products');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  barcode: '',
  buying_price: '',
  description: '',
  erp_id: '',
  name: '',
  product_number: '',
  selling_price: ''
});

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}}/products',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    barcode: '',
    buying_price: '',
    description: '',
    erp_id: '',
    name: '',
    product_number: '',
    selling_price: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/products';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"barcode":"","buying_price":"","description":"","erp_id":"","name":"","product_number":"","selling_price":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"barcode": @"",
                              @"buying_price": @"",
                              @"description": @"",
                              @"erp_id": @"",
                              @"name": @"",
                              @"product_number": @"",
                              @"selling_price": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/products"]
                                                       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}}/products" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/products",
  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([
    'barcode' => '',
    'buying_price' => '',
    'description' => '',
    'erp_id' => '',
    'name' => '',
    'product_number' => '',
    'selling_price' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/products', [
  'body' => '{
  "barcode": "",
  "buying_price": "",
  "description": "",
  "erp_id": "",
  "name": "",
  "product_number": "",
  "selling_price": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/products');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'barcode' => '',
  'buying_price' => '',
  'description' => '',
  'erp_id' => '',
  'name' => '',
  'product_number' => '',
  'selling_price' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'barcode' => '',
  'buying_price' => '',
  'description' => '',
  'erp_id' => '',
  'name' => '',
  'product_number' => '',
  'selling_price' => ''
]));
$request->setRequestUrl('{{baseUrl}}/products');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/products' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "barcode": "",
  "buying_price": "",
  "description": "",
  "erp_id": "",
  "name": "",
  "product_number": "",
  "selling_price": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/products' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "barcode": "",
  "buying_price": "",
  "description": "",
  "erp_id": "",
  "name": "",
  "product_number": "",
  "selling_price": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/products", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/products"

payload = {
    "barcode": "",
    "buying_price": "",
    "description": "",
    "erp_id": "",
    "name": "",
    "product_number": "",
    "selling_price": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/products"

payload <- "{\n  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/products")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\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/products') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"barcode\": \"\",\n  \"buying_price\": \"\",\n  \"description\": \"\",\n  \"erp_id\": \"\",\n  \"name\": \"\",\n  \"product_number\": \"\",\n  \"selling_price\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/products";

    let payload = json!({
        "barcode": "",
        "buying_price": "",
        "description": "",
        "erp_id": "",
        "name": "",
        "product_number": "",
        "selling_price": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/products \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "barcode": "",
  "buying_price": "",
  "description": "",
  "erp_id": "",
  "name": "",
  "product_number": "",
  "selling_price": ""
}'
echo '{
  "barcode": "",
  "buying_price": "",
  "description": "",
  "erp_id": "",
  "name": "",
  "product_number": "",
  "selling_price": ""
}' |  \
  http POST {{baseUrl}}/products \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "barcode": "",\n  "buying_price": "",\n  "description": "",\n  "erp_id": "",\n  "name": "",\n  "product_number": "",\n  "selling_price": ""\n}' \
  --output-document \
  - {{baseUrl}}/products
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "barcode": "",
  "buying_price": "",
  "description": "",
  "erp_id": "",
  "name": "",
  "product_number": "",
  "selling_price": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/products")! 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 Bulk delete products
{{baseUrl}}/products/bulkDelete
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/products/bulkDelete");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/products/bulkDelete" {:headers {:x-auth-token "{{apiKey}}"}
                                                                  :content-type :json
                                                                  :form-params {:id []}})
require "http/client"

url = "{{baseUrl}}/products/bulkDelete"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": []\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}}/products/bulkDelete"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id\": []\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}}/products/bulkDelete");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/products/bulkDelete"

	payload := strings.NewReader("{\n  \"id\": []\n}")

	req, _ := http.NewRequest("DELETE", url, payload)

	req.Header.Add("x-auth-token", "{{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/products/bulkDelete HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/products/bulkDelete")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/products/bulkDelete"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"id\": []\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\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/products/bulkDelete")
  .delete(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/products/bulkDelete")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/products/bulkDelete');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/products/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/products/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/products/bulkDelete',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/products/bulkDelete")
  .delete(body)
  .addHeader("x-auth-token", "{{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/products/bulkDelete',
  headers: {
    'x-auth-token': '{{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: []}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/products/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {id: []},
  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}}/products/bulkDelete');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: []
});

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}}/products/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/products/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/products/bulkDelete"]
                                                       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}}/products/bulkDelete" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": []\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/products/bulkDelete",
  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([
    'id' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/products/bulkDelete', [
  'body' => '{
  "id": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/products/bulkDelete');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/products/bulkDelete');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/products/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/products/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": []\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("DELETE", "/baseUrl/products/bulkDelete", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/products/bulkDelete"

payload = { "id": [] }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/products/bulkDelete"

payload <- "{\n  \"id\": []\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/products/bulkDelete")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/products/bulkDelete') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"id\": []\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}}/products/bulkDelete";

    let payload = json!({"id": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/products/bulkDelete \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http DELETE {{baseUrl}}/products/bulkDelete \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/products/bulkDelete
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/products/bulkDelete")! 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 a product
{{baseUrl}}/products/:product_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

product_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/products/:product_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/products/:product_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/products/:product_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/products/:product_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/products/:product_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/products/:product_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/products/:product_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/products/:product_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/products/:product_id"))
    .header("x-auth-token", "{{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}}/products/:product_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/products/:product_id")
  .header("x-auth-token", "{{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}}/products/:product_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/products/:product_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/products/:product_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/products/:product_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/products/:product_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/products/:product_id',
  headers: {
    'x-auth-token': '{{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}}/products/:product_id',
  headers: {'x-auth-token': '{{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}}/products/:product_id');

req.headers({
  'x-auth-token': '{{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}}/products/:product_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/products/:product_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/products/:product_id"]
                                                       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}}/products/:product_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/products/:product_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/products/:product_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/products/:product_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/products/:product_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/products/:product_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/products/:product_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/products/:product_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/products/:product_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/products/:product_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/products/:product_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/products/:product_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/products/:product_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/products/:product_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/products/:product_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/products/:product_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/products/:product_id")! 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()
PUT Edit a product
{{baseUrl}}/products/:product_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

product_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/products/:product_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/products/:product_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/products/:product_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/products/:product_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/products/:product_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/products/:product_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/products/:product_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/products/:product_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/products/:product_id"))
    .header("x-auth-token", "{{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}}/products/:product_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/products/:product_id")
  .header("x-auth-token", "{{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}}/products/:product_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/products/:product_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/products/:product_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/products/:product_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/products/:product_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/products/:product_id',
  headers: {
    'x-auth-token': '{{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}}/products/:product_id',
  headers: {'x-auth-token': '{{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}}/products/:product_id');

req.headers({
  'x-auth-token': '{{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}}/products/:product_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/products/:product_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/products/:product_id"]
                                                       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}}/products/:product_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/products/:product_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/products/:product_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/products/:product_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/products/:product_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/products/:product_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/products/:product_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/products/:product_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/products/:product_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/products/:product_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/products/:product_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/products/:product_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/products/:product_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/products/:product_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/products/:product_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/products/:product_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/products/:product_id")! 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()
GET List products
{{baseUrl}}/products
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/products");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/products" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/products"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/products"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/products");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/products"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/products HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/products")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/products"))
    .header("x-auth-token", "{{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}}/products")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/products")
  .header("x-auth-token", "{{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}}/products');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/products',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/products';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/products',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/products")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/products',
  headers: {
    'x-auth-token': '{{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}}/products',
  headers: {'x-auth-token': '{{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}}/products');

req.headers({
  'x-auth-token': '{{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}}/products',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/products';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/products"]
                                                       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}}/products" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/products",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/products', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/products');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/products');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/products' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/products' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/products", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/products"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/products"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/products")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/products') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/products";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/products \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/products \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/products
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/products")! 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 Restore a deleted product
{{baseUrl}}/products/undelete/:product_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

product_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/products/undelete/:product_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/products/undelete/:product_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/products/undelete/:product_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
}

response = HTTP::Client.post url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/products/undelete/:product_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/products/undelete/:product_id");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/products/undelete/:product_id"

	req, _ := http.NewRequest("POST", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/products/undelete/:product_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/products/undelete/:product_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/products/undelete/:product_id"))
    .header("x-auth-token", "{{apiKey}}")
    .method("POST", 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}}/products/undelete/:product_id")
  .post(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/products/undelete/:product_id")
  .header("x-auth-token", "{{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('POST', '{{baseUrl}}/products/undelete/:product_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/products/undelete/:product_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/products/undelete/:product_id';
const options = {method: 'POST', headers: {'x-auth-token': '{{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}}/products/undelete/:product_id',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/products/undelete/:product_id")
  .post(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/products/undelete/:product_id',
  headers: {
    'x-auth-token': '{{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: 'POST',
  url: '{{baseUrl}}/products/undelete/:product_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/products/undelete/:product_id');

req.headers({
  'x-auth-token': '{{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: 'POST',
  url: '{{baseUrl}}/products/undelete/:product_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/products/undelete/:product_id';
const options = {method: 'POST', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/products/undelete/:product_id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[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}}/products/undelete/:product_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/products/undelete/:product_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/products/undelete/:product_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/products/undelete/:product_id');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/products/undelete/:product_id');
$request->setRequestMethod('POST');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/products/undelete/:product_id' -Method POST -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/products/undelete/:product_id' -Method POST -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("POST", "/baseUrl/products/undelete/:product_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/products/undelete/:product_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.post(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/products/undelete/:product_id"

response <- VERB("POST", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/products/undelete/:product_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/products/undelete/:product_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/products/undelete/:product_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/products/undelete/:product_id \
  --header 'x-auth-token: {{apiKey}}'
http POST {{baseUrl}}/products/undelete/:product_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/products/undelete/:product_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/products/undelete/:product_id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
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 Upload or delete product image
{{baseUrl}}/products/:product_id/uploadImage
BODY formUrlEncoded

image
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/products/:product_id/uploadImage");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/x-www-form-urlencoded");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "image=");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/products/:product_id/uploadImage" {:form-params {:image ""}})
require "http/client"

url = "{{baseUrl}}/products/:product_id/uploadImage"
headers = HTTP::Headers{
  "content-type" => "application/x-www-form-urlencoded"
}
reqBody = "image="

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}}/products/:product_id/uploadImage"),
    Content = new FormUrlEncodedContent(new Dictionary
    {
        { "image", "" },
    }),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/products/:product_id/uploadImage");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/x-www-form-urlencoded");
request.AddParameter("application/x-www-form-urlencoded", "image=", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/products/:product_id/uploadImage"

	payload := strings.NewReader("image=")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/x-www-form-urlencoded")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/products/:product_id/uploadImage HTTP/1.1
Content-Type: application/x-www-form-urlencoded
Host: example.com
Content-Length: 6

image=
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/products/:product_id/uploadImage")
  .setHeader("content-type", "application/x-www-form-urlencoded")
  .setBody("image=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/products/:product_id/uploadImage"))
    .header("content-type", "application/x-www-form-urlencoded")
    .method("POST", HttpRequest.BodyPublishers.ofString("image="))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/x-www-form-urlencoded");
RequestBody body = RequestBody.create(mediaType, "image=");
Request request = new Request.Builder()
  .url("{{baseUrl}}/products/:product_id/uploadImage")
  .post(body)
  .addHeader("content-type", "application/x-www-form-urlencoded")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/products/:product_id/uploadImage")
  .header("content-type", "application/x-www-form-urlencoded")
  .body("image=")
  .asString();
const data = 'image=';

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/products/:product_id/uploadImage');
xhr.setRequestHeader('content-type', 'application/x-www-form-urlencoded');

xhr.send(data);
import axios from 'axios';

const encodedParams = new URLSearchParams();
encodedParams.set('image', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/products/:product_id/uploadImage',
  headers: {'content-type': 'application/x-www-form-urlencoded'},
  data: encodedParams,
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/products/:product_id/uploadImage';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/x-www-form-urlencoded'},
  body: new URLSearchParams({image: ''})
};

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}}/products/:product_id/uploadImage',
  method: 'POST',
  headers: {
    'content-type': 'application/x-www-form-urlencoded'
  },
  data: {
    image: ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/x-www-form-urlencoded")
val body = RequestBody.create(mediaType, "image=")
val request = Request.Builder()
  .url("{{baseUrl}}/products/:product_id/uploadImage")
  .post(body)
  .addHeader("content-type", "application/x-www-form-urlencoded")
  .build()

val response = client.newCall(request).execute()
const qs = require('querystring');
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/products/:product_id/uploadImage',
  headers: {
    'content-type': 'application/x-www-form-urlencoded'
  }
};

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(qs.stringify({image: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/products/:product_id/uploadImage',
  headers: {'content-type': 'application/x-www-form-urlencoded'},
  form: {image: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/products/:product_id/uploadImage');

req.headers({
  'content-type': 'application/x-www-form-urlencoded'
});

req.form({
  image: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;
const { URLSearchParams } = require('url');

const encodedParams = new URLSearchParams();
encodedParams.set('image', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/products/:product_id/uploadImage',
  headers: {'content-type': 'application/x-www-form-urlencoded'},
  data: encodedParams,
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const { URLSearchParams } = require('url');
const fetch = require('node-fetch');

const encodedParams = new URLSearchParams();
encodedParams.set('image', '');

const url = '{{baseUrl}}/products/:product_id/uploadImage';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/x-www-form-urlencoded'},
  body: encodedParams
};

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/x-www-form-urlencoded" };

NSMutableData *postData = [[NSMutableData alloc] initWithData:[@"image=" dataUsingEncoding:NSUTF8StringEncoding]];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/products/:product_id/uploadImage"]
                                                       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}}/products/:product_id/uploadImage" in
let headers = Header.add (Header.init ()) "content-type" "application/x-www-form-urlencoded" in
let body = Cohttp_lwt_body.of_string "image=" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/products/:product_id/uploadImage",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => "image=",
  CURLOPT_HTTPHEADER => [
    "content-type: application/x-www-form-urlencoded"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/products/:product_id/uploadImage', [
  'form_params' => [
    'image' => ''
  ],
  'headers' => [
    'content-type' => 'application/x-www-form-urlencoded',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/products/:product_id/uploadImage');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/x-www-form-urlencoded'
]);

$request->setContentType('application/x-www-form-urlencoded');
$request->setPostFields([
  'image' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(new http\QueryString([
  'image' => ''
]));

$request->setRequestUrl('{{baseUrl}}/products/:product_id/uploadImage');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/x-www-form-urlencoded'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/x-www-form-urlencoded")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/products/:product_id/uploadImage' -Method POST -Headers $headers -ContentType 'application/x-www-form-urlencoded' -Body 'image='
$headers=@{}
$headers.Add("content-type", "application/x-www-form-urlencoded")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/products/:product_id/uploadImage' -Method POST -Headers $headers -ContentType 'application/x-www-form-urlencoded' -Body 'image='
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "image="

headers = { 'content-type': "application/x-www-form-urlencoded" }

conn.request("POST", "/baseUrl/products/:product_id/uploadImage", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/products/:product_id/uploadImage"

payload = { "image": "" }
headers = {"content-type": "application/x-www-form-urlencoded"}

response = requests.post(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/products/:product_id/uploadImage"

payload <- "image="

encode <- "form"

response <- VERB("POST", url, body = payload, content_type("application/x-www-form-urlencoded"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/products/:product_id/uploadImage")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/x-www-form-urlencoded'
request.body = "image="

response = http.request(request)
puts response.read_body
require 'faraday'

data = {
  :image => "",
}

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/x-www-form-urlencoded'}
)

response = conn.post('/baseUrl/products/:product_id/uploadImage') do |req|
  req.body = URI.encode_www_form(data)
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/products/:product_id/uploadImage";

    let payload = json!({"image": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/x-www-form-urlencoded".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .form(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/products/:product_id/uploadImage \
  --header 'content-type: application/x-www-form-urlencoded' \
  --data image=
http --form POST {{baseUrl}}/products/:product_id/uploadImage \
  content-type:application/x-www-form-urlencoded \
  image=''
wget --quiet \
  --method POST \
  --header 'content-type: application/x-www-form-urlencoded' \
  --body-data image= \
  --output-document \
  - {{baseUrl}}/products/:product_id/uploadImage
import Foundation

let headers = ["content-type": "application/x-www-form-urlencoded"]

let postData = NSMutableData(data: "image=".data(using: String.Encoding.utf8)!)

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/products/:product_id/uploadImage")! 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 View single product
{{baseUrl}}/products/:product_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

product_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/products/:product_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/products/:product_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/products/:product_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/products/:product_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/products/:product_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/products/:product_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/products/:product_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/products/:product_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/products/:product_id"))
    .header("x-auth-token", "{{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}}/products/:product_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/products/:product_id")
  .header("x-auth-token", "{{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}}/products/:product_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/products/:product_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/products/:product_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/products/:product_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/products/:product_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/products/:product_id',
  headers: {
    'x-auth-token': '{{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}}/products/:product_id',
  headers: {'x-auth-token': '{{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}}/products/:product_id');

req.headers({
  'x-auth-token': '{{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}}/products/:product_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/products/:product_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/products/:product_id"]
                                                       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}}/products/:product_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/products/:product_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/products/:product_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/products/:product_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/products/:product_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/products/:product_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/products/:product_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/products/:product_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/products/:product_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/products/:product_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/products/:product_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/products/:product_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/products/:product_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/products/:product_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/products/:product_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/products/:product_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/products/:product_id")! 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 a new variant to a product
{{baseUrl}}/products/:product_id/variants
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

product_id
BODY formUrlEncoded

ratio
variant_id
variant_type
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/products/:product_id/variants");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/x-www-form-urlencoded");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "ratio=&variant_id=&variant_type=");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/products/:product_id/variants" {:headers {:x-auth-token "{{apiKey}}"}
                                                                          :form-params {:ratio ""
                                                                                        :variant_id ""
                                                                                        :variant_type ""}})
require "http/client"

url = "{{baseUrl}}/products/:product_id/variants"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/x-www-form-urlencoded"
}
reqBody = "ratio=&variant_id=&variant_type="

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}}/products/:product_id/variants"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new FormUrlEncodedContent(new Dictionary
    {
        { "ratio", "" },
        { "variant_id", "" },
        { "variant_type", "" },
    }),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/products/:product_id/variants");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/x-www-form-urlencoded");
request.AddParameter("application/x-www-form-urlencoded", "ratio=&variant_id=&variant_type=", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/products/:product_id/variants"

	payload := strings.NewReader("ratio=&variant_id=&variant_type=")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{apiKey}}")
	req.Header.Add("content-type", "application/x-www-form-urlencoded")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/products/:product_id/variants HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/x-www-form-urlencoded
Host: example.com
Content-Length: 32

ratio=&variant_id=&variant_type=
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/products/:product_id/variants")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/x-www-form-urlencoded")
  .setBody("ratio=&variant_id=&variant_type=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/products/:product_id/variants"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/x-www-form-urlencoded")
    .method("POST", HttpRequest.BodyPublishers.ofString("ratio=&variant_id=&variant_type="))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/x-www-form-urlencoded");
RequestBody body = RequestBody.create(mediaType, "ratio=&variant_id=&variant_type=");
Request request = new Request.Builder()
  .url("{{baseUrl}}/products/:product_id/variants")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/x-www-form-urlencoded")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/products/:product_id/variants")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/x-www-form-urlencoded")
  .body("ratio=&variant_id=&variant_type=")
  .asString();
const data = 'ratio=&variant_id=&variant_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}}/products/:product_id/variants');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/x-www-form-urlencoded');

xhr.send(data);
import axios from 'axios';

const encodedParams = new URLSearchParams();
encodedParams.set('ratio', '');
encodedParams.set('variant_id', '');
encodedParams.set('variant_type', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/products/:product_id/variants',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  data: encodedParams,
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/products/:product_id/variants';
const options = {
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  body: new URLSearchParams({ratio: '', variant_id: '', variant_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}}/products/:product_id/variants',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  data: {
    ratio: '',
    variant_id: '',
    variant_type: ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/x-www-form-urlencoded")
val body = RequestBody.create(mediaType, "ratio=&variant_id=&variant_type=")
val request = Request.Builder()
  .url("{{baseUrl}}/products/:product_id/variants")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/x-www-form-urlencoded")
  .build()

val response = client.newCall(request).execute()
const qs = require('querystring');
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/products/:product_id/variants',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  }
};

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(qs.stringify({ratio: '', variant_id: '', variant_type: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/products/:product_id/variants',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  form: {ratio: '', variant_id: '', variant_type: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/products/:product_id/variants');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/x-www-form-urlencoded'
});

req.form({
  ratio: '',
  variant_id: '',
  variant_type: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;
const { URLSearchParams } = require('url');

const encodedParams = new URLSearchParams();
encodedParams.set('ratio', '');
encodedParams.set('variant_id', '');
encodedParams.set('variant_type', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/products/:product_id/variants',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  data: encodedParams,
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const { URLSearchParams } = require('url');
const fetch = require('node-fetch');

const encodedParams = new URLSearchParams();
encodedParams.set('ratio', '');
encodedParams.set('variant_id', '');
encodedParams.set('variant_type', '');

const url = '{{baseUrl}}/products/:product_id/variants';
const options = {
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  body: encodedParams
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/x-www-form-urlencoded" };

NSMutableData *postData = [[NSMutableData alloc] initWithData:[@"ratio=" dataUsingEncoding:NSUTF8StringEncoding]];
[postData appendData:[@"&variant_id=" dataUsingEncoding:NSUTF8StringEncoding]];
[postData appendData:[@"&variant_type=" dataUsingEncoding:NSUTF8StringEncoding]];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/products/:product_id/variants"]
                                                       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}}/products/:product_id/variants" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/x-www-form-urlencoded");
] in
let body = Cohttp_lwt_body.of_string "ratio=&variant_id=&variant_type=" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/products/:product_id/variants",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => "ratio=&variant_id=&variant_type=",
  CURLOPT_HTTPHEADER => [
    "content-type: application/x-www-form-urlencoded",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/products/:product_id/variants', [
  'form_params' => [
    'ratio' => '',
    'variant_id' => '',
    'variant_type' => ''
  ],
  'headers' => [
    'content-type' => 'application/x-www-form-urlencoded',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/products/:product_id/variants');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/x-www-form-urlencoded'
]);

$request->setContentType('application/x-www-form-urlencoded');
$request->setPostFields([
  'ratio' => '',
  'variant_id' => '',
  'variant_type' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(new http\QueryString([
  'ratio' => '',
  'variant_id' => '',
  'variant_type' => ''
]));

$request->setRequestUrl('{{baseUrl}}/products/:product_id/variants');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/x-www-form-urlencoded'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/x-www-form-urlencoded")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/products/:product_id/variants' -Method POST -Headers $headers -ContentType 'application/x-www-form-urlencoded' -Body 'ratio=&variant_id=&variant_type='
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/x-www-form-urlencoded")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/products/:product_id/variants' -Method POST -Headers $headers -ContentType 'application/x-www-form-urlencoded' -Body 'ratio=&variant_id=&variant_type='
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "ratio=&variant_id=&variant_type="

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/x-www-form-urlencoded"
}

conn.request("POST", "/baseUrl/products/:product_id/variants", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/products/:product_id/variants"

payload = {
    "ratio": "",
    "variant_id": "",
    "variant_type": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/x-www-form-urlencoded"
}

response = requests.post(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/products/:product_id/variants"

payload <- "ratio=&variant_id=&variant_type="

encode <- "form"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/x-www-form-urlencoded"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/products/:product_id/variants")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/x-www-form-urlencoded'
request.body = "ratio=&variant_id=&variant_type="

response = http.request(request)
puts response.read_body
require 'faraday'

data = {
  :ratio => "",
  :variant_id => "",
  :variant_type => "",
}

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/x-www-form-urlencoded'}
)

response = conn.post('/baseUrl/products/:product_id/variants') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = URI.encode_www_form(data)
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/products/:product_id/variants";

    let payload = json!({
        "ratio": "",
        "variant_id": "",
        "variant_type": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/x-www-form-urlencoded".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .form(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/products/:product_id/variants \
  --header 'content-type: application/x-www-form-urlencoded' \
  --header 'x-auth-token: {{apiKey}}' \
  --data ratio= \
  --data variant_id= \
  --data variant_type=
http --form POST {{baseUrl}}/products/:product_id/variants \
  content-type:application/x-www-form-urlencoded \
  x-auth-token:'{{apiKey}}' \
  ratio='' \
  variant_id='' \
  variant_type=''
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/x-www-form-urlencoded' \
  --body-data 'ratio=&variant_id=&variant_type=' \
  --output-document \
  - {{baseUrl}}/products/:product_id/variants
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/x-www-form-urlencoded"
]

let postData = NSMutableData(data: "ratio=".data(using: String.Encoding.utf8)!)
postData.append("&variant_id=".data(using: String.Encoding.utf8)!)
postData.append("&variant_type=".data(using: String.Encoding.utf8)!)

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/products/:product_id/variants")! 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 Delete a product variant
{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id
QUERY PARAMS

product_id
variant_type
variant_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id")
require "http/client"

url = "{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/products/:product_id/variants/:variant_type/:variant_id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id"))
    .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}}/products/:product_id/variants/:variant_type/:variant_id")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id")
  .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}}/products/:product_id/variants/:variant_type/:variant_id');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/products/:product_id/variants/:variant_type/:variant_id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id');

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}}/products/:product_id/variants/:variant_type/:variant_id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id');

echo $response->getBody();
setUrl('{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/products/:product_id/variants/:variant_type/:variant_id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/products/:product_id/variants/:variant_type/:variant_id') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id
http DELETE {{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/products/:product_id/variants/:variant_type/:variant_id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET Get a product's variants
{{baseUrl}}/products/:product_id/variants
QUERY PARAMS

product_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/products/:product_id/variants");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/products/:product_id/variants")
require "http/client"

url = "{{baseUrl}}/products/:product_id/variants"

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}}/products/:product_id/variants"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/products/:product_id/variants");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/products/:product_id/variants"

	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/products/:product_id/variants HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/products/:product_id/variants")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/products/:product_id/variants"))
    .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}}/products/:product_id/variants")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/products/:product_id/variants")
  .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}}/products/:product_id/variants');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/products/:product_id/variants'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/products/:product_id/variants';
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}}/products/:product_id/variants',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/products/:product_id/variants")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/products/:product_id/variants',
  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}}/products/:product_id/variants'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/products/:product_id/variants');

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}}/products/:product_id/variants'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/products/:product_id/variants';
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}}/products/:product_id/variants"]
                                                       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}}/products/:product_id/variants" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/products/:product_id/variants",
  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}}/products/:product_id/variants');

echo $response->getBody();
setUrl('{{baseUrl}}/products/:product_id/variants');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/products/:product_id/variants');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/products/:product_id/variants' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/products/:product_id/variants' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/products/:product_id/variants")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/products/:product_id/variants"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/products/:product_id/variants"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/products/:product_id/variants")

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/products/:product_id/variants') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/products/:product_id/variants";

    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}}/products/:product_id/variants
http GET {{baseUrl}}/products/:product_id/variants
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/products/:product_id/variants
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/products/:product_id/variants")! 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 Details of 1 project custom field attribute
{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_custom_field_attribute_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/project_custom_field_attributes/:project_custom_field_attribute_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/project_custom_field_attributes/:project_custom_field_attribute_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id"))
    .header("x-auth-token", "{{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}}/project_custom_field_attributes/:project_custom_field_attribute_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id")
  .header("x-auth-token", "{{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}}/project_custom_field_attributes/:project_custom_field_attribute_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/project_custom_field_attributes/:project_custom_field_attribute_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/project_custom_field_attributes/:project_custom_field_attribute_id',
  headers: {
    'x-auth-token': '{{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}}/project_custom_field_attributes/:project_custom_field_attribute_id',
  headers: {'x-auth-token': '{{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}}/project_custom_field_attributes/:project_custom_field_attribute_id');

req.headers({
  'x-auth-token': '{{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}}/project_custom_field_attributes/:project_custom_field_attribute_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id"]
                                                       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}}/project_custom_field_attributes/:project_custom_field_attribute_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/project_custom_field_attributes/:project_custom_field_attribute_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/project_custom_field_attributes/:project_custom_field_attribute_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/project_custom_field_attributes/:project_custom_field_attribute_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/project_custom_field_attributes/:project_custom_field_attribute_id")! 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 a list of project custom field attributes
{{baseUrl}}/project_custom_field_attributes
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/project_custom_field_attributes");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/project_custom_field_attributes" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/project_custom_field_attributes"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/project_custom_field_attributes"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/project_custom_field_attributes");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/project_custom_field_attributes"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/project_custom_field_attributes HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/project_custom_field_attributes")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/project_custom_field_attributes"))
    .header("x-auth-token", "{{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}}/project_custom_field_attributes")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/project_custom_field_attributes")
  .header("x-auth-token", "{{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}}/project_custom_field_attributes');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/project_custom_field_attributes',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/project_custom_field_attributes';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/project_custom_field_attributes',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/project_custom_field_attributes")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/project_custom_field_attributes',
  headers: {
    'x-auth-token': '{{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}}/project_custom_field_attributes',
  headers: {'x-auth-token': '{{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}}/project_custom_field_attributes');

req.headers({
  'x-auth-token': '{{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}}/project_custom_field_attributes',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/project_custom_field_attributes';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/project_custom_field_attributes"]
                                                       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}}/project_custom_field_attributes" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/project_custom_field_attributes",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/project_custom_field_attributes', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/project_custom_field_attributes');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/project_custom_field_attributes');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/project_custom_field_attributes' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/project_custom_field_attributes' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/project_custom_field_attributes", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/project_custom_field_attributes"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/project_custom_field_attributes"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/project_custom_field_attributes")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/project_custom_field_attributes') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/project_custom_field_attributes";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/project_custom_field_attributes \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/project_custom_field_attributes \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/project_custom_field_attributes
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/project_custom_field_attributes")! 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 a project
{{baseUrl}}/projects
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "child_projects": [
    {}
  ],
  "city_id": "",
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "parent_id": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/projects" {:headers {:x-auth-token "{{apiKey}}"}
                                                     :content-type :json
                                                     :form-params {:child_projects [{}]
                                                                   :city_id ""
                                                                   :contact_id ""
                                                                   :description ""
                                                                   :erp_project_id ""
                                                                   :erp_task_id ""
                                                                   :name ""
                                                                   :parent_id ""
                                                                   :project_status_id ""
                                                                   :start_time ""
                                                                   :street_name ""}})
require "http/client"

url = "{{baseUrl}}/projects"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_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}}/projects"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_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}}/projects");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects"

	payload := strings.NewReader("{\n  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/projects HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 240

{
  "child_projects": [
    {}
  ],
  "city_id": "",
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "parent_id": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/projects")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_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  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/projects")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  child_projects: [
    {}
  ],
  city_id: '',
  contact_id: '',
  description: '',
  erp_project_id: '',
  erp_task_id: '',
  name: '',
  parent_id: '',
  project_status_id: '',
  start_time: '',
  street_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}}/projects');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    child_projects: [{}],
    city_id: '',
    contact_id: '',
    description: '',
    erp_project_id: '',
    erp_task_id: '',
    name: '',
    parent_id: '',
    project_status_id: '',
    start_time: '',
    street_name: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"child_projects":[{}],"city_id":"","contact_id":"","description":"","erp_project_id":"","erp_task_id":"","name":"","parent_id":"","project_status_id":"","start_time":"","street_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}}/projects',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "child_projects": [\n    {}\n  ],\n  "city_id": "",\n  "contact_id": "",\n  "description": "",\n  "erp_project_id": "",\n  "erp_task_id": "",\n  "name": "",\n  "parent_id": "",\n  "project_status_id": "",\n  "start_time": "",\n  "street_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  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects")
  .post(body)
  .addHeader("x-auth-token", "{{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/projects',
  headers: {
    'x-auth-token': '{{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({
  child_projects: [{}],
  city_id: '',
  contact_id: '',
  description: '',
  erp_project_id: '',
  erp_task_id: '',
  name: '',
  parent_id: '',
  project_status_id: '',
  start_time: '',
  street_name: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    child_projects: [{}],
    city_id: '',
    contact_id: '',
    description: '',
    erp_project_id: '',
    erp_task_id: '',
    name: '',
    parent_id: '',
    project_status_id: '',
    start_time: '',
    street_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}}/projects');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  child_projects: [
    {}
  ],
  city_id: '',
  contact_id: '',
  description: '',
  erp_project_id: '',
  erp_task_id: '',
  name: '',
  parent_id: '',
  project_status_id: '',
  start_time: '',
  street_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}}/projects',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    child_projects: [{}],
    city_id: '',
    contact_id: '',
    description: '',
    erp_project_id: '',
    erp_task_id: '',
    name: '',
    parent_id: '',
    project_status_id: '',
    start_time: '',
    street_name: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"child_projects":[{}],"city_id":"","contact_id":"","description":"","erp_project_id":"","erp_task_id":"","name":"","parent_id":"","project_status_id":"","start_time":"","street_name":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"child_projects": @[ @{  } ],
                              @"city_id": @"",
                              @"contact_id": @"",
                              @"description": @"",
                              @"erp_project_id": @"",
                              @"erp_task_id": @"",
                              @"name": @"",
                              @"parent_id": @"",
                              @"project_status_id": @"",
                              @"start_time": @"",
                              @"street_name": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects"]
                                                       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}}/projects" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects",
  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([
    'child_projects' => [
        [
                
        ]
    ],
    'city_id' => '',
    'contact_id' => '',
    'description' => '',
    'erp_project_id' => '',
    'erp_task_id' => '',
    'name' => '',
    'parent_id' => '',
    'project_status_id' => '',
    'start_time' => '',
    'street_name' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/projects', [
  'body' => '{
  "child_projects": [
    {}
  ],
  "city_id": "",
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "parent_id": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'child_projects' => [
    [
        
    ]
  ],
  'city_id' => '',
  'contact_id' => '',
  'description' => '',
  'erp_project_id' => '',
  'erp_task_id' => '',
  'name' => '',
  'parent_id' => '',
  'project_status_id' => '',
  'start_time' => '',
  'street_name' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'child_projects' => [
    [
        
    ]
  ],
  'city_id' => '',
  'contact_id' => '',
  'description' => '',
  'erp_project_id' => '',
  'erp_task_id' => '',
  'name' => '',
  'parent_id' => '',
  'project_status_id' => '',
  'start_time' => '',
  'street_name' => ''
]));
$request->setRequestUrl('{{baseUrl}}/projects');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "child_projects": [
    {}
  ],
  "city_id": "",
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "parent_id": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "child_projects": [
    {}
  ],
  "city_id": "",
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "parent_id": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/projects", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects"

payload = {
    "child_projects": [{}],
    "city_id": "",
    "contact_id": "",
    "description": "",
    "erp_project_id": "",
    "erp_task_id": "",
    "name": "",
    "parent_id": "",
    "project_status_id": "",
    "start_time": "",
    "street_name": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects"

payload <- "{\n  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_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/projects') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"child_projects\": [\n    {}\n  ],\n  \"city_id\": \"\",\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"parent_id\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects";

    let payload = json!({
        "child_projects": (json!({})),
        "city_id": "",
        "contact_id": "",
        "description": "",
        "erp_project_id": "",
        "erp_task_id": "",
        "name": "",
        "parent_id": "",
        "project_status_id": "",
        "start_time": "",
        "street_name": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "child_projects": [
    {}
  ],
  "city_id": "",
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "parent_id": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
}'
echo '{
  "child_projects": [
    {}
  ],
  "city_id": "",
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "parent_id": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
}' |  \
  http POST {{baseUrl}}/projects \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "child_projects": [\n    {}\n  ],\n  "city_id": "",\n  "contact_id": "",\n  "description": "",\n  "erp_project_id": "",\n  "erp_task_id": "",\n  "name": "",\n  "parent_id": "",\n  "project_status_id": "",\n  "start_time": "",\n  "street_name": ""\n}' \
  --output-document \
  - {{baseUrl}}/projects
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "child_projects": [[]],
  "city_id": "",
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "parent_id": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects")! 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 project file to projects
{{baseUrl}}/projects/:project_id/project_files
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
BODY multipartForm

Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/project_files");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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}}/projects/:project_id/project_files" {:headers {:x-auth-token "{{apiKey}}"}
                                                                               :multipart [{:name "file"
                                                                                            :content ""}]})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/project_files"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id/project_files"),
    Headers =
    {
        { "x-auth-token", "{{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}}/projects/:project_id/project_files");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{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}}/projects/:project_id/project_files"

	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("x-auth-token", "{{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/projects/:project_id/project_files HTTP/1.1
X-Auth-Token: {{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}}/projects/:project_id/project_files")
  .setHeader("x-auth-token", "{{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}}/projects/:project_id/project_files"))
    .header("x-auth-token", "{{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}}/projects/:project_id/project_files")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/projects/:project_id/project_files")
  .header("x-auth-token", "{{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}}/projects/:project_id/project_files');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const form = new FormData();
form.append('file', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:project_id/project_files',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/project_files';
const form = new FormData();
form.append('file', '');

const options = {method: 'POST', headers: {'x-auth-token': '{{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}}/projects/:project_id/project_files',
  method: 'POST',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/project_files")
  .post(body)
  .addHeader("x-auth-token", "{{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/projects/:project_id/project_files',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/project_files',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/project_files');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id/project_files',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/project_files';
const options = {method: 'POST', headers: {'x-auth-token': '{{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 = @{ @"x-auth-token": @"{{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}}/projects/:project_id/project_files"]
                                                       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}}/projects/:project_id/project_files" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{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}}/projects/:project_id/project_files",
  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 => [
    "content-type: multipart/form-data; boundary=---011000010111000001101001",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/projects/:project_id/project_files', [
  'headers' => [
    'content-type' => 'multipart/form-data; boundary=---011000010111000001101001',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/project_files');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{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}}/projects/:project_id/project_files');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/project_files' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="file"


-----011000010111000001101001--
'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/project_files' -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 = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "multipart/form-data; boundary=---011000010111000001101001"
}

conn.request("POST", "/baseUrl/projects/:project_id/project_files", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/project_files"

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"file\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "multipart/form-data; boundary=---011000010111000001101001"
}

response = requests.post(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/project_files"

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('x-auth-token' = '{{apiKey}}'), content_type("multipart/form-data"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/project_files")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{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/projects/:project_id/project_files') do |req|
  req.headers['x-auth-token'] = '{{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}}/projects/:project_id/project_files";

    let form = reqwest::multipart::Form::new()
        .text("file", "");
    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/project_files \
  --header 'content-type: multipart/form-data' \
  --header 'x-auth-token: {{apiKey}}' \
  --form file=
echo '-----011000010111000001101001
Content-Disposition: form-data; name="file"


-----011000010111000001101001--
' |  \
  http POST {{baseUrl}}/projects/:project_id/project_files \
  content-type:'multipart/form-data; boundary=---011000010111000001101001' \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{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}}/projects/:project_id/project_files
import Foundation

let headers = [
  "x-auth-token": "{{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}}/projects/:project_id/project_files")! 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 user to project
{{baseUrl}}/projects/:project_id/users/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
BODY json

{
  "user_id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/users/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"user_id\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/projects/:project_id/users/" {:headers {:x-auth-token "{{apiKey}}"}
                                                                        :content-type :json
                                                                        :form-params {:user_id ""}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/users/"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"user_id\": \"\"\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}}/projects/:project_id/users/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"user_id\": \"\"\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}}/projects/:project_id/users/");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"user_id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id/users/"

	payload := strings.NewReader("{\n  \"user_id\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/projects/:project_id/users/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "user_id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/projects/:project_id/users/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"user_id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id/users/"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"user_id\": \"\"\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  \"user_id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/users/")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/projects/:project_id/users/")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"user_id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  user_id: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/projects/:project_id/users/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:project_id/users/',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {user_id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id/users/';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"user_id":""}'
};

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}}/projects/:project_id/users/',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "user_id": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"user_id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/users/")
  .post(body)
  .addHeader("x-auth-token", "{{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/projects/:project_id/users/',
  headers: {
    'x-auth-token': '{{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({user_id: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:project_id/users/',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {user_id: ''},
  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}}/projects/:project_id/users/');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  user_id: ''
});

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}}/projects/:project_id/users/',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {user_id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id/users/';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"user_id":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"user_id": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id/users/"]
                                                       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}}/projects/:project_id/users/" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"user_id\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id/users/",
  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([
    'user_id' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/projects/:project_id/users/', [
  'body' => '{
  "user_id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/users/');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'user_id' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'user_id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/projects/:project_id/users/');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/users/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "user_id": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/users/' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "user_id": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"user_id\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/projects/:project_id/users/", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/users/"

payload = { "user_id": "" }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/users/"

payload <- "{\n  \"user_id\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/users/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"user_id\": \"\"\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/projects/:project_id/users/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"user_id\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id/users/";

    let payload = json!({"user_id": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/users/ \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "user_id": ""
}'
echo '{
  "user_id": ""
}' |  \
  http POST {{baseUrl}}/projects/:project_id/users/ \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "user_id": ""\n}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id/users/
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["user_id": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id/users/")! 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 Delete a project
{{baseUrl}}/projects/:project_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/projects/:project_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:project_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/projects/:project_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/projects/:project_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id"))
    .header("x-auth-token", "{{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}}/projects/:project_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/projects/:project_id")
  .header("x-auth-token", "{{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}}/projects/:project_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/projects/:project_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/projects/:project_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:project_id',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id',
  headers: {'x-auth-token': '{{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}}/projects/:project_id');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id"]
                                                       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}}/projects/:project_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/projects/:project_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:project_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/projects/:project_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/projects/:project_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/projects/:project_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id")! 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 file (DELETE)
{{baseUrl}}/projects/:project_id/files/:file_id/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
file_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/files/:file_id/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/projects/:project_id/files/:file_id/" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/files/:file_id/"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id/files/:file_id/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:project_id/files/:file_id/");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id/files/:file_id/"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/projects/:project_id/files/:file_id/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/projects/:project_id/files/:file_id/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id/files/:file_id/"))
    .header("x-auth-token", "{{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}}/projects/:project_id/files/:file_id/")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/projects/:project_id/files/:file_id/")
  .header("x-auth-token", "{{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}}/projects/:project_id/files/:file_id/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/projects/:project_id/files/:file_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id/files/:file_id/';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/projects/:project_id/files/:file_id/',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/files/:file_id/")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:project_id/files/:file_id/',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/files/:file_id/',
  headers: {'x-auth-token': '{{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}}/projects/:project_id/files/:file_id/');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id/files/:file_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id/files/:file_id/';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id/files/:file_id/"]
                                                       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}}/projects/:project_id/files/:file_id/" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id/files/:file_id/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/projects/:project_id/files/:file_id/', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/files/:file_id/');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:project_id/files/:file_id/');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/files/:file_id/' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/files/:file_id/' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/projects/:project_id/files/:file_id/", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/files/:file_id/"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/files/:file_id/"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/files/:file_id/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/projects/:project_id/files/:file_id/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id/files/:file_id/";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/files/:file_id/ \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/projects/:project_id/files/:file_id/ \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id/files/:file_id/
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id/files/:file_id/")! 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 project file
{{baseUrl}}/projects/:project_id/project_files/:project_file_id/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_file_id
project_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id/project_files/:project_file_id/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/projects/:project_id/project_files/:project_file_id/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"))
    .header("x-auth-token", "{{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}}/projects/:project_id/project_files/:project_file_id/")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")
  .header("x-auth-token", "{{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}}/projects/:project_id/project_files/:project_file_id/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/projects/:project_id/project_files/:project_file_id/',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:project_id/project_files/:project_file_id/',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/project_files/:project_file_id/',
  headers: {'x-auth-token': '{{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}}/projects/:project_id/project_files/:project_file_id/');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id/project_files/:project_file_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"]
                                                       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}}/projects/:project_id/project_files/:project_file_id/" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/project_files/:project_file_id/');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:project_id/project_files/:project_file_id/');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/projects/:project_id/project_files/:project_file_id/", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/projects/:project_id/project_files/:project_file_id/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/project_files/:project_file_id/ \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/projects/:project_id/project_files/:project_file_id/ \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id/project_files/:project_file_id/
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")! 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 user from project
{{baseUrl}}/projects/:project_id/users/:user_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
project_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/users/:user_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/projects/:project_id/users/:user_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/users/:user_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id/users/:user_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:project_id/users/:user_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id/users/:user_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/projects/:project_id/users/:user_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/projects/:project_id/users/:user_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id/users/:user_id"))
    .header("x-auth-token", "{{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}}/projects/:project_id/users/:user_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/projects/:project_id/users/:user_id")
  .header("x-auth-token", "{{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}}/projects/:project_id/users/:user_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/projects/:project_id/users/:user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id/users/:user_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/projects/:project_id/users/:user_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/users/:user_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:project_id/users/:user_id',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/users/:user_id',
  headers: {'x-auth-token': '{{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}}/projects/:project_id/users/:user_id');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id/users/:user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id/users/:user_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id/users/:user_id"]
                                                       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}}/projects/:project_id/users/:user_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id/users/:user_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/projects/:project_id/users/:user_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/users/:user_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:project_id/users/:user_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/users/:user_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/users/:user_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/projects/:project_id/users/:user_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/users/:user_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/users/:user_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/users/:user_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/projects/:project_id/users/:user_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id/users/:user_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/users/:user_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/projects/:project_id/users/:user_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id/users/:user_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id/users/:user_id")! 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()
PUT Edit a project
{{baseUrl}}/projects/:project_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
BODY json

{
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/projects/:project_id" {:headers {:x-auth-token "{{apiKey}}"}
                                                                :content-type :json
                                                                :form-params {:contact_id ""
                                                                              :description ""
                                                                              :erp_project_id ""
                                                                              :erp_task_id ""
                                                                              :name ""
                                                                              :project_status_id ""
                                                                              :start_time ""
                                                                              :street_name ""}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_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}}/projects/:project_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_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}}/projects/:project_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id"

	payload := strings.NewReader("{\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("x-auth-token", "{{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/projects/:project_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 170

{
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/projects/:project_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_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  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:project_id")
  .put(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/projects/:project_id")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  contact_id: '',
  description: '',
  erp_project_id: '',
  erp_task_id: '',
  name: '',
  project_status_id: '',
  start_time: '',
  street_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}}/projects/:project_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/projects/:project_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    contact_id: '',
    description: '',
    erp_project_id: '',
    erp_task_id: '',
    name: '',
    project_status_id: '',
    start_time: '',
    street_name: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id';
const options = {
  method: 'PUT',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"contact_id":"","description":"","erp_project_id":"","erp_task_id":"","name":"","project_status_id":"","start_time":"","street_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}}/projects/:project_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "contact_id": "",\n  "description": "",\n  "erp_project_id": "",\n  "erp_task_id": "",\n  "name": "",\n  "project_status_id": "",\n  "start_time": "",\n  "street_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  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id")
  .put(body)
  .addHeader("x-auth-token", "{{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/projects/:project_id',
  headers: {
    'x-auth-token': '{{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({
  contact_id: '',
  description: '',
  erp_project_id: '',
  erp_task_id: '',
  name: '',
  project_status_id: '',
  start_time: '',
  street_name: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/projects/:project_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    contact_id: '',
    description: '',
    erp_project_id: '',
    erp_task_id: '',
    name: '',
    project_status_id: '',
    start_time: '',
    street_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}}/projects/:project_id');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  contact_id: '',
  description: '',
  erp_project_id: '',
  erp_task_id: '',
  name: '',
  project_status_id: '',
  start_time: '',
  street_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}}/projects/:project_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    contact_id: '',
    description: '',
    erp_project_id: '',
    erp_task_id: '',
    name: '',
    project_status_id: '',
    start_time: '',
    street_name: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id';
const options = {
  method: 'PUT',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"contact_id":"","description":"","erp_project_id":"","erp_task_id":"","name":"","project_status_id":"","start_time":"","street_name":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"contact_id": @"",
                              @"description": @"",
                              @"erp_project_id": @"",
                              @"erp_task_id": @"",
                              @"name": @"",
                              @"project_status_id": @"",
                              @"start_time": @"",
                              @"street_name": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id"]
                                                       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}}/projects/:project_id" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id",
  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([
    'contact_id' => '',
    'description' => '',
    'erp_project_id' => '',
    'erp_task_id' => '',
    'name' => '',
    'project_status_id' => '',
    'start_time' => '',
    'street_name' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/projects/:project_id', [
  'body' => '{
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'contact_id' => '',
  'description' => '',
  'erp_project_id' => '',
  'erp_task_id' => '',
  'name' => '',
  'project_status_id' => '',
  'start_time' => '',
  'street_name' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'contact_id' => '',
  'description' => '',
  'erp_project_id' => '',
  'erp_task_id' => '',
  'name' => '',
  'project_status_id' => '',
  'start_time' => '',
  'street_name' => ''
]));
$request->setRequestUrl('{{baseUrl}}/projects/:project_id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/projects/:project_id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id"

payload = {
    "contact_id": "",
    "description": "",
    "erp_project_id": "",
    "erp_task_id": "",
    "name": "",
    "project_status_id": "",
    "start_time": "",
    "street_name": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id"

payload <- "{\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_name\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_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/projects/:project_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"contact_id\": \"\",\n  \"description\": \"\",\n  \"erp_project_id\": \"\",\n  \"erp_task_id\": \"\",\n  \"name\": \"\",\n  \"project_status_id\": \"\",\n  \"start_time\": \"\",\n  \"street_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}}/projects/:project_id";

    let payload = json!({
        "contact_id": "",
        "description": "",
        "erp_project_id": "",
        "erp_task_id": "",
        "name": "",
        "project_status_id": "",
        "start_time": "",
        "street_name": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
}'
echo '{
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
}' |  \
  http PUT {{baseUrl}}/projects/:project_id \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "contact_id": "",\n  "description": "",\n  "erp_project_id": "",\n  "erp_task_id": "",\n  "name": "",\n  "project_status_id": "",\n  "start_time": "",\n  "street_name": ""\n}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "contact_id": "",
  "description": "",
  "erp_project_id": "",
  "erp_task_id": "",
  "name": "",
  "project_status_id": "",
  "start_time": "",
  "street_name": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id")! 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()
PUT Edit file (PUT)
{{baseUrl}}/projects/:project_id/files/:file_id/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
file_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/files/:file_id/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/projects/:project_id/files/:file_id/" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/files/:file_id/"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id/files/:file_id/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:project_id/files/:file_id/");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id/files/:file_id/"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/projects/:project_id/files/:file_id/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/projects/:project_id/files/:file_id/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id/files/:file_id/"))
    .header("x-auth-token", "{{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}}/projects/:project_id/files/:file_id/")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/projects/:project_id/files/:file_id/")
  .header("x-auth-token", "{{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}}/projects/:project_id/files/:file_id/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/projects/:project_id/files/:file_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id/files/:file_id/';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/projects/:project_id/files/:file_id/',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/files/:file_id/")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:project_id/files/:file_id/',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/files/:file_id/',
  headers: {'x-auth-token': '{{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}}/projects/:project_id/files/:file_id/');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id/files/:file_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id/files/:file_id/';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id/files/:file_id/"]
                                                       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}}/projects/:project_id/files/:file_id/" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id/files/:file_id/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/projects/:project_id/files/:file_id/', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/files/:file_id/');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:project_id/files/:file_id/');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/files/:file_id/' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/files/:file_id/' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/projects/:project_id/files/:file_id/", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/files/:file_id/"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/files/:file_id/"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/files/:file_id/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/projects/:project_id/files/:file_id/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id/files/:file_id/";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/files/:file_id/ \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/projects/:project_id/files/:file_id/ \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id/files/:file_id/
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id/files/:file_id/")! 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 Edit project file
{{baseUrl}}/projects/:project_id/project_files/:project_file_id/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
project_file_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id/project_files/:project_file_id/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/projects/:project_id/project_files/:project_file_id/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"))
    .header("x-auth-token", "{{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}}/projects/:project_id/project_files/:project_file_id/")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")
  .header("x-auth-token", "{{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}}/projects/:project_id/project_files/:project_file_id/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/projects/:project_id/project_files/:project_file_id/',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:project_id/project_files/:project_file_id/',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/project_files/:project_file_id/',
  headers: {'x-auth-token': '{{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}}/projects/:project_id/project_files/:project_file_id/');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id/project_files/:project_file_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"]
                                                       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}}/projects/:project_id/project_files/:project_file_id/" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/project_files/:project_file_id/');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:project_id/project_files/:project_file_id/');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/projects/:project_id/project_files/:project_file_id/", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/projects/:project_id/project_files/:project_file_id/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/project_files/:project_file_id/ \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/projects/:project_id/project_files/:project_file_id/ \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id/project_files/:project_file_id/
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")! 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()
POST Send bulk forms pdf by email
{{baseUrl}}/projects/:project_id/send_bulk_pdf
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
BODY json

{
  "form_id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/send_bulk_pdf");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"form_id\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/projects/:project_id/send_bulk_pdf" {:headers {:x-auth-token "{{apiKey}}"}
                                                                               :content-type :json
                                                                               :form-params {:form_id []}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/send_bulk_pdf"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"form_id\": []\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}}/projects/:project_id/send_bulk_pdf"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"form_id\": []\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}}/projects/:project_id/send_bulk_pdf");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"form_id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id/send_bulk_pdf"

	payload := strings.NewReader("{\n  \"form_id\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/projects/:project_id/send_bulk_pdf HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "form_id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/projects/:project_id/send_bulk_pdf")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"form_id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id/send_bulk_pdf"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"form_id\": []\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  \"form_id\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/send_bulk_pdf")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/projects/:project_id/send_bulk_pdf")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"form_id\": []\n}")
  .asString();
const data = JSON.stringify({
  form_id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/projects/:project_id/send_bulk_pdf');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:project_id/send_bulk_pdf',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {form_id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id/send_bulk_pdf';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"form_id":[]}'
};

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}}/projects/:project_id/send_bulk_pdf',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "form_id": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"form_id\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/send_bulk_pdf")
  .post(body)
  .addHeader("x-auth-token", "{{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/projects/:project_id/send_bulk_pdf',
  headers: {
    'x-auth-token': '{{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({form_id: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:project_id/send_bulk_pdf',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {form_id: []},
  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}}/projects/:project_id/send_bulk_pdf');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  form_id: []
});

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}}/projects/:project_id/send_bulk_pdf',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {form_id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id/send_bulk_pdf';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"form_id":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"form_id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id/send_bulk_pdf"]
                                                       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}}/projects/:project_id/send_bulk_pdf" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"form_id\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id/send_bulk_pdf",
  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([
    'form_id' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/projects/:project_id/send_bulk_pdf', [
  'body' => '{
  "form_id": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/send_bulk_pdf');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'form_id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'form_id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/projects/:project_id/send_bulk_pdf');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/send_bulk_pdf' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "form_id": []
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/send_bulk_pdf' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "form_id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"form_id\": []\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/projects/:project_id/send_bulk_pdf", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/send_bulk_pdf"

payload = { "form_id": [] }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/send_bulk_pdf"

payload <- "{\n  \"form_id\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/send_bulk_pdf")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"form_id\": []\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/projects/:project_id/send_bulk_pdf') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"form_id\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id/send_bulk_pdf";

    let payload = json!({"form_id": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/send_bulk_pdf \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "form_id": []
}'
echo '{
  "form_id": []
}' |  \
  http POST {{baseUrl}}/projects/:project_id/send_bulk_pdf \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "form_id": []\n}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id/send_bulk_pdf
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["form_id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id/send_bulk_pdf")! 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 Show file (GET)
{{baseUrl}}/projects/:project_id/files/:file_id/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
file_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/files/:file_id/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/projects/:project_id/files/:file_id/" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/files/:file_id/"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id/files/:file_id/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:project_id/files/:file_id/");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id/files/:file_id/"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/projects/:project_id/files/:file_id/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:project_id/files/:file_id/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id/files/:file_id/"))
    .header("x-auth-token", "{{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}}/projects/:project_id/files/:file_id/")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:project_id/files/:file_id/")
  .header("x-auth-token", "{{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}}/projects/:project_id/files/:file_id/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:project_id/files/:file_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id/files/:file_id/';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/projects/:project_id/files/:file_id/',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/files/:file_id/")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:project_id/files/:file_id/',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/files/:file_id/',
  headers: {'x-auth-token': '{{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}}/projects/:project_id/files/:file_id/');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id/files/:file_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id/files/:file_id/';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id/files/:file_id/"]
                                                       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}}/projects/:project_id/files/:file_id/" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id/files/:file_id/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/projects/:project_id/files/:file_id/', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/files/:file_id/');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:project_id/files/:file_id/');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/files/:file_id/' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/files/:file_id/' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/projects/:project_id/files/:file_id/", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/files/:file_id/"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/files/:file_id/"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/files/:file_id/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/projects/:project_id/files/:file_id/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id/files/:file_id/";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/files/:file_id/ \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/projects/:project_id/files/:file_id/ \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id/files/:file_id/
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id/files/:file_id/")! 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 Show list of all files uploaded to project
{{baseUrl}}/projects/:project_id/all_files
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/all_files");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/projects/:project_id/all_files" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/all_files"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id/all_files"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:project_id/all_files");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id/all_files"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/projects/:project_id/all_files HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:project_id/all_files")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id/all_files"))
    .header("x-auth-token", "{{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}}/projects/:project_id/all_files")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:project_id/all_files")
  .header("x-auth-token", "{{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}}/projects/:project_id/all_files');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:project_id/all_files',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id/all_files';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/projects/:project_id/all_files',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/all_files")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:project_id/all_files',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/all_files',
  headers: {'x-auth-token': '{{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}}/projects/:project_id/all_files');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id/all_files',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id/all_files';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id/all_files"]
                                                       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}}/projects/:project_id/all_files" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id/all_files",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/projects/:project_id/all_files', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/all_files');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:project_id/all_files');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/all_files' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/all_files' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/projects/:project_id/all_files", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/all_files"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/all_files"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/all_files")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/projects/:project_id/all_files') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id/all_files";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/all_files \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/projects/:project_id/all_files \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id/all_files
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id/all_files")! 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 Show list of files uploaded to project
{{baseUrl}}/projects/:project_id/files
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/files");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/projects/:project_id/files" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/files"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id/files"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:project_id/files");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id/files"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/projects/:project_id/files HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:project_id/files")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id/files"))
    .header("x-auth-token", "{{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}}/projects/:project_id/files")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:project_id/files")
  .header("x-auth-token", "{{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}}/projects/:project_id/files');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:project_id/files',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id/files';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/projects/:project_id/files',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/files")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:project_id/files',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/files',
  headers: {'x-auth-token': '{{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}}/projects/:project_id/files');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id/files',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id/files';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id/files"]
                                                       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}}/projects/:project_id/files" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id/files",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/projects/:project_id/files', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/files');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:project_id/files');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/files' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/files' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/projects/:project_id/files", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/files"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/files"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/files")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/projects/:project_id/files') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id/files";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/files \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/projects/:project_id/files \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id/files
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id/files")! 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 Show list of project files uploaded to project
{{baseUrl}}/projects/:project_id/project_files
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/project_files");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/projects/:project_id/project_files" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/project_files"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id/project_files"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:project_id/project_files");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id/project_files"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/projects/:project_id/project_files HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:project_id/project_files")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id/project_files"))
    .header("x-auth-token", "{{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}}/projects/:project_id/project_files")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:project_id/project_files")
  .header("x-auth-token", "{{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}}/projects/:project_id/project_files');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:project_id/project_files',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id/project_files';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/projects/:project_id/project_files',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/project_files")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:project_id/project_files',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/project_files',
  headers: {'x-auth-token': '{{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}}/projects/:project_id/project_files');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id/project_files',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id/project_files';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id/project_files"]
                                                       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}}/projects/:project_id/project_files" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id/project_files",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/projects/:project_id/project_files', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/project_files');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:project_id/project_files');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/project_files' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/project_files' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/projects/:project_id/project_files", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/project_files"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/project_files"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/project_files")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/projects/:project_id/project_files') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id/project_files";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/project_files \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/projects/:project_id/project_files \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id/project_files
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id/project_files")! 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 Show list of users added to project
{{baseUrl}}/projects/:project_id/users/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/users/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/projects/:project_id/users/" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/users/"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id/users/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:project_id/users/");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id/users/"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/projects/:project_id/users/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:project_id/users/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id/users/"))
    .header("x-auth-token", "{{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}}/projects/:project_id/users/")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:project_id/users/")
  .header("x-auth-token", "{{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}}/projects/:project_id/users/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:project_id/users/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id/users/';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/projects/:project_id/users/',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/users/")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:project_id/users/',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/users/',
  headers: {'x-auth-token': '{{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}}/projects/:project_id/users/');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id/users/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id/users/';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id/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}}/projects/:project_id/users/" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id/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 => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/projects/:project_id/users/', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/users/');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:project_id/users/');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/users/' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/users/' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/projects/:project_id/users/", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/users/"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/users/"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/users/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/projects/:project_id/users/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id/users/";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/users/ \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/projects/:project_id/users/ \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id/users/
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id/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()
GET Show project file
{{baseUrl}}/projects/:project_id/project_files/:project_file_id/
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
project_file_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id/project_files/:project_file_id/"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/projects/:project_id/project_files/:project_file_id/ HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"))
    .header("x-auth-token", "{{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}}/projects/:project_id/project_files/:project_file_id/")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")
  .header("x-auth-token", "{{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}}/projects/:project_id/project_files/:project_file_id/');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/projects/:project_id/project_files/:project_file_id/',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:project_id/project_files/:project_file_id/',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/project_files/:project_file_id/',
  headers: {'x-auth-token': '{{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}}/projects/:project_id/project_files/:project_file_id/');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id/project_files/:project_file_id/',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"]
                                                       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}}/projects/:project_id/project_files/:project_file_id/" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/project_files/:project_file_id/');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:project_id/project_files/:project_file_id/');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/project_files/:project_file_id/' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/projects/:project_id/project_files/:project_file_id/", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/projects/:project_id/project_files/:project_file_id/') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/project_files/:project_file_id/ \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/projects/:project_id/project_files/:project_file_id/ \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id/project_files/:project_file_id/
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id/project_files/:project_file_id/")! 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 View list of projects
{{baseUrl}}/projects
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/projects" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/projects HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects"))
    .header("x-auth-token", "{{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}}/projects")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects")
  .header("x-auth-token", "{{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}}/projects');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/projects',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects',
  headers: {
    'x-auth-token': '{{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}}/projects',
  headers: {'x-auth-token': '{{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}}/projects');

req.headers({
  'x-auth-token': '{{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}}/projects',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects"]
                                                       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}}/projects" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/projects', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/projects", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/projects') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/projects \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects")! 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 View specific project
{{baseUrl}}/projects/:project_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/projects/:project_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:project_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/projects/:project_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:project_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id"))
    .header("x-auth-token", "{{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}}/projects/:project_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:project_id")
  .header("x-auth-token", "{{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}}/projects/:project_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:project_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/projects/:project_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:project_id',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id',
  headers: {'x-auth-token': '{{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}}/projects/:project_id');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id"]
                                                       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}}/projects/:project_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/projects/:project_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:project_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/projects/:project_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/projects/:project_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/projects/:project_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id")! 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 View specific user assigned to project
{{baseUrl}}/projects/:project_id/users/:user_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
project_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:project_id/users/:user_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/projects/:project_id/users/:user_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/:project_id/users/:user_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/:project_id/users/:user_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:project_id/users/:user_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:project_id/users/:user_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/projects/:project_id/users/:user_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:project_id/users/:user_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:project_id/users/:user_id"))
    .header("x-auth-token", "{{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}}/projects/:project_id/users/:user_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:project_id/users/:user_id")
  .header("x-auth-token", "{{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}}/projects/:project_id/users/:user_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:project_id/users/:user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:project_id/users/:user_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/projects/:project_id/users/:user_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:project_id/users/:user_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:project_id/users/:user_id',
  headers: {
    'x-auth-token': '{{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}}/projects/:project_id/users/:user_id',
  headers: {'x-auth-token': '{{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}}/projects/:project_id/users/:user_id');

req.headers({
  'x-auth-token': '{{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}}/projects/:project_id/users/:user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:project_id/users/:user_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:project_id/users/:user_id"]
                                                       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}}/projects/:project_id/users/:user_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:project_id/users/:user_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/projects/:project_id/users/:user_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:project_id/users/:user_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:project_id/users/:user_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:project_id/users/:user_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:project_id/users/:user_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/projects/:project_id/users/:user_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:project_id/users/:user_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:project_id/users/:user_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:project_id/users/:user_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/projects/:project_id/users/:user_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:project_id/users/:user_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/:project_id/users/:user_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/projects/:project_id/users/:user_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/:project_id/users/:user_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:project_id/users/:user_id")! 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 Bulk delete project statuses
{{baseUrl}}/project_statuses/bulkDelete
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/project_statuses/bulkDelete");

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  \"id\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/project_statuses/bulkDelete" {:content-type :json
                                                                          :form-params {:id []}})
require "http/client"

url = "{{baseUrl}}/project_statuses/bulkDelete"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": []\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}}/project_statuses/bulkDelete"),
    Content = new StringContent("{\n  \"id\": []\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}}/project_statuses/bulkDelete");
var request = new RestRequest("", Method.Delete);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/project_statuses/bulkDelete"

	payload := strings.NewReader("{\n  \"id\": []\n}")

	req, _ := http.NewRequest("DELETE", 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))

}
DELETE /baseUrl/project_statuses/bulkDelete HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/project_statuses/bulkDelete")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/project_statuses/bulkDelete"))
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"id\": []\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\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/project_statuses/bulkDelete")
  .delete(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/project_statuses/bulkDelete")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/project_statuses/bulkDelete');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/project_statuses/bulkDelete',
  headers: {'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/project_statuses/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/project_statuses/bulkDelete',
  method: 'DELETE',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/project_statuses/bulkDelete")
  .delete(body)
  .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/project_statuses/bulkDelete',
  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({id: []}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/project_statuses/bulkDelete',
  headers: {'content-type': 'application/json'},
  body: {id: []},
  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}}/project_statuses/bulkDelete');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: []
});

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}}/project_statuses/bulkDelete',
  headers: {'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/project_statuses/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'content-type': 'application/json'},
  body: '{"id":[]}'
};

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 = @{ @"id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/project_statuses/bulkDelete"]
                                                       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}}/project_statuses/bulkDelete" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": []\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/project_statuses/bulkDelete",
  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([
    'id' => [
        
    ]
  ]),
  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('DELETE', '{{baseUrl}}/project_statuses/bulkDelete', [
  'body' => '{
  "id": []
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/project_statuses/bulkDelete');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/project_statuses/bulkDelete');
$request->setRequestMethod('DELETE');
$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}}/project_statuses/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/project_statuses/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": []\n}"

headers = { 'content-type': "application/json" }

conn.request("DELETE", "/baseUrl/project_statuses/bulkDelete", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/project_statuses/bulkDelete"

payload = { "id": [] }
headers = {"content-type": "application/json"}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/project_statuses/bulkDelete"

payload <- "{\n  \"id\": []\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/project_statuses/bulkDelete")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/project_statuses/bulkDelete') do |req|
  req.body = "{\n  \"id\": []\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}}/project_statuses/bulkDelete";

    let payload = json!({"id": ()});

    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("DELETE").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/project_statuses/bulkDelete \
  --header 'content-type: application/json' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http DELETE {{baseUrl}}/project_statuses/bulkDelete \
  content-type:application/json
wget --quiet \
  --method DELETE \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/project_statuses/bulkDelete
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/project_statuses/bulkDelete")! 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 Check if the company has projects with custom statuses
{{baseUrl}}/projects/has_projects_with_custom_statuses
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/has_projects_with_custom_statuses");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/projects/has_projects_with_custom_statuses" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/projects/has_projects_with_custom_statuses"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/projects/has_projects_with_custom_statuses"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/has_projects_with_custom_statuses");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/has_projects_with_custom_statuses"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/projects/has_projects_with_custom_statuses HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/has_projects_with_custom_statuses")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/has_projects_with_custom_statuses"))
    .header("x-auth-token", "{{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}}/projects/has_projects_with_custom_statuses")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/has_projects_with_custom_statuses")
  .header("x-auth-token", "{{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}}/projects/has_projects_with_custom_statuses');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/has_projects_with_custom_statuses',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/has_projects_with_custom_statuses';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/projects/has_projects_with_custom_statuses',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/projects/has_projects_with_custom_statuses")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/has_projects_with_custom_statuses',
  headers: {
    'x-auth-token': '{{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}}/projects/has_projects_with_custom_statuses',
  headers: {'x-auth-token': '{{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}}/projects/has_projects_with_custom_statuses');

req.headers({
  'x-auth-token': '{{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}}/projects/has_projects_with_custom_statuses',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/has_projects_with_custom_statuses';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/has_projects_with_custom_statuses"]
                                                       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}}/projects/has_projects_with_custom_statuses" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/has_projects_with_custom_statuses",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/projects/has_projects_with_custom_statuses', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/has_projects_with_custom_statuses');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/has_projects_with_custom_statuses');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/has_projects_with_custom_statuses' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/has_projects_with_custom_statuses' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/projects/has_projects_with_custom_statuses", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/has_projects_with_custom_statuses"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/has_projects_with_custom_statuses"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/has_projects_with_custom_statuses")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/projects/has_projects_with_custom_statuses') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/has_projects_with_custom_statuses";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/projects/has_projects_with_custom_statuses \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/projects/has_projects_with_custom_statuses \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/projects/has_projects_with_custom_statuses
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/has_projects_with_custom_statuses")! 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 Create a new project status
{{baseUrl}}/project_statuses
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "description": "",
  "name": "",
  "project_status_type_id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/project_statuses");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/project_statuses" {:headers {:x-auth-token "{{apiKey}}"}
                                                             :content-type :json
                                                             :form-params {:description ""
                                                                           :name ""
                                                                           :project_status_type_id ""}})
require "http/client"

url = "{{baseUrl}}/project_statuses"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\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}}/project_statuses"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\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}}/project_statuses");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/project_statuses"

	payload := strings.NewReader("{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/project_statuses HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 69

{
  "description": "",
  "name": "",
  "project_status_type_id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/project_statuses")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/project_statuses"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\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  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/project_statuses")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/project_statuses")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  description: '',
  name: '',
  project_status_type_id: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/project_statuses');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/project_statuses',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {description: '', name: '', project_status_type_id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/project_statuses';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"description":"","name":"","project_status_type_id":""}'
};

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}}/project_statuses',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "description": "",\n  "name": "",\n  "project_status_type_id": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/project_statuses")
  .post(body)
  .addHeader("x-auth-token", "{{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/project_statuses',
  headers: {
    'x-auth-token': '{{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({description: '', name: '', project_status_type_id: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/project_statuses',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {description: '', name: '', project_status_type_id: ''},
  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}}/project_statuses');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  description: '',
  name: '',
  project_status_type_id: ''
});

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}}/project_statuses',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {description: '', name: '', project_status_type_id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/project_statuses';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"description":"","name":"","project_status_type_id":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"description": @"",
                              @"name": @"",
                              @"project_status_type_id": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/project_statuses"]
                                                       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}}/project_statuses" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/project_statuses",
  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([
    'description' => '',
    'name' => '',
    'project_status_type_id' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/project_statuses', [
  'body' => '{
  "description": "",
  "name": "",
  "project_status_type_id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/project_statuses');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'description' => '',
  'name' => '',
  'project_status_type_id' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'description' => '',
  'name' => '',
  'project_status_type_id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/project_statuses');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/project_statuses' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "description": "",
  "name": "",
  "project_status_type_id": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/project_statuses' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "description": "",
  "name": "",
  "project_status_type_id": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/project_statuses", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/project_statuses"

payload = {
    "description": "",
    "name": "",
    "project_status_type_id": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/project_statuses"

payload <- "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/project_statuses")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\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/project_statuses') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"project_status_type_id\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/project_statuses";

    let payload = json!({
        "description": "",
        "name": "",
        "project_status_type_id": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/project_statuses \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "description": "",
  "name": "",
  "project_status_type_id": ""
}'
echo '{
  "description": "",
  "name": "",
  "project_status_type_id": ""
}' |  \
  http POST {{baseUrl}}/project_statuses \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "description": "",\n  "name": "",\n  "project_status_type_id": ""\n}' \
  --output-document \
  - {{baseUrl}}/project_statuses
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "description": "",
  "name": "",
  "project_status_type_id": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/project_statuses")! 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 Delete a project status
{{baseUrl}}/project_statuses/:project_status_id
QUERY PARAMS

project_status_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/project_statuses/:project_status_id");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/project_statuses/:project_status_id")
require "http/client"

url = "{{baseUrl}}/project_statuses/:project_status_id"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/project_statuses/:project_status_id"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/project_statuses/:project_status_id");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/project_statuses/:project_status_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/project_statuses/:project_status_id HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/project_statuses/:project_status_id")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/project_statuses/:project_status_id"))
    .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}}/project_statuses/:project_status_id")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/project_statuses/:project_status_id")
  .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}}/project_statuses/:project_status_id');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/project_statuses/:project_status_id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/project_statuses/:project_status_id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/project_statuses/:project_status_id',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/project_statuses/:project_status_id")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/project_statuses/:project_status_id',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/project_statuses/:project_status_id'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/project_statuses/:project_status_id');

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}}/project_statuses/:project_status_id'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/project_statuses/:project_status_id';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/project_statuses/:project_status_id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/project_statuses/:project_status_id" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/project_statuses/:project_status_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/project_statuses/:project_status_id');

echo $response->getBody();
setUrl('{{baseUrl}}/project_statuses/:project_status_id');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/project_statuses/:project_status_id');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/project_statuses/:project_status_id' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/project_statuses/:project_status_id' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/project_statuses/:project_status_id")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/project_statuses/:project_status_id"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/project_statuses/:project_status_id"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/project_statuses/:project_status_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/project_statuses/:project_status_id') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/project_statuses/:project_status_id";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/project_statuses/:project_status_id
http DELETE {{baseUrl}}/project_statuses/:project_status_id
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/project_statuses/:project_status_id
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/project_statuses/:project_status_id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT Edit a project status
{{baseUrl}}/project_statuses/:project_status_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_status_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/project_statuses/:project_status_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/project_statuses/:project_status_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/project_statuses/:project_status_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/project_statuses/:project_status_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/project_statuses/:project_status_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/project_statuses/:project_status_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/project_statuses/:project_status_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/project_statuses/:project_status_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/project_statuses/:project_status_id"))
    .header("x-auth-token", "{{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}}/project_statuses/:project_status_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/project_statuses/:project_status_id")
  .header("x-auth-token", "{{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}}/project_statuses/:project_status_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/project_statuses/:project_status_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/project_statuses/:project_status_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/project_statuses/:project_status_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/project_statuses/:project_status_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/project_statuses/:project_status_id',
  headers: {
    'x-auth-token': '{{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}}/project_statuses/:project_status_id',
  headers: {'x-auth-token': '{{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}}/project_statuses/:project_status_id');

req.headers({
  'x-auth-token': '{{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}}/project_statuses/:project_status_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/project_statuses/:project_status_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/project_statuses/:project_status_id"]
                                                       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}}/project_statuses/:project_status_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/project_statuses/:project_status_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/project_statuses/:project_status_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/project_statuses/:project_status_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/project_statuses/:project_status_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/project_statuses/:project_status_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/project_statuses/:project_status_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/project_statuses/:project_status_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/project_statuses/:project_status_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/project_statuses/:project_status_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/project_statuses/:project_status_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/project_statuses/:project_status_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/project_statuses/:project_status_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/project_statuses/:project_status_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/project_statuses/:project_status_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/project_statuses/:project_status_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/project_statuses/:project_status_id")! 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()
GET Get a single project status
{{baseUrl}}/project_statuses/:project_status_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

project_status_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/project_statuses/:project_status_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/project_statuses/:project_status_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/project_statuses/:project_status_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/project_statuses/:project_status_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/project_statuses/:project_status_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/project_statuses/:project_status_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/project_statuses/:project_status_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/project_statuses/:project_status_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/project_statuses/:project_status_id"))
    .header("x-auth-token", "{{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}}/project_statuses/:project_status_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/project_statuses/:project_status_id")
  .header("x-auth-token", "{{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}}/project_statuses/:project_status_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/project_statuses/:project_status_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/project_statuses/:project_status_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/project_statuses/:project_status_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/project_statuses/:project_status_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/project_statuses/:project_status_id',
  headers: {
    'x-auth-token': '{{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}}/project_statuses/:project_status_id',
  headers: {'x-auth-token': '{{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}}/project_statuses/:project_status_id');

req.headers({
  'x-auth-token': '{{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}}/project_statuses/:project_status_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/project_statuses/:project_status_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/project_statuses/:project_status_id"]
                                                       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}}/project_statuses/:project_status_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/project_statuses/:project_status_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/project_statuses/:project_status_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/project_statuses/:project_status_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/project_statuses/:project_status_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/project_statuses/:project_status_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/project_statuses/:project_status_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/project_statuses/:project_status_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/project_statuses/:project_status_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/project_statuses/:project_status_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/project_statuses/:project_status_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/project_statuses/:project_status_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/project_statuses/:project_status_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/project_statuses/:project_status_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/project_statuses/:project_status_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/project_statuses/:project_status_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/project_statuses/:project_status_id")! 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 list of project statuses
{{baseUrl}}/project_statuses
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/project_statuses");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/project_statuses" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/project_statuses"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/project_statuses"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/project_statuses");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/project_statuses"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/project_statuses HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/project_statuses")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/project_statuses"))
    .header("x-auth-token", "{{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}}/project_statuses")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/project_statuses")
  .header("x-auth-token", "{{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}}/project_statuses');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/project_statuses',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/project_statuses';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/project_statuses',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/project_statuses")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/project_statuses',
  headers: {
    'x-auth-token': '{{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}}/project_statuses',
  headers: {'x-auth-token': '{{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}}/project_statuses');

req.headers({
  'x-auth-token': '{{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}}/project_statuses',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/project_statuses';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/project_statuses"]
                                                       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}}/project_statuses" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/project_statuses",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/project_statuses', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/project_statuses');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/project_statuses');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/project_statuses' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/project_statuses' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/project_statuses", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/project_statuses"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/project_statuses"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/project_statuses")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/project_statuses') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/project_statuses";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/project_statuses \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/project_statuses \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/project_statuses
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/project_statuses")! 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 a list of project status types
{{baseUrl}}/project_status_types
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/project_status_types");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/project_status_types" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/project_status_types"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/project_status_types"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/project_status_types");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/project_status_types"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/project_status_types HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/project_status_types")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/project_status_types"))
    .header("x-auth-token", "{{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}}/project_status_types")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/project_status_types")
  .header("x-auth-token", "{{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}}/project_status_types');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/project_status_types',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/project_status_types';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/project_status_types',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/project_status_types")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/project_status_types',
  headers: {
    'x-auth-token': '{{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}}/project_status_types',
  headers: {'x-auth-token': '{{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}}/project_status_types');

req.headers({
  'x-auth-token': '{{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}}/project_status_types',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/project_status_types';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/project_status_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}}/project_status_types" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/project_status_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 => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/project_status_types', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/project_status_types');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/project_status_types');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/project_status_types' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/project_status_types' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/project_status_types", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/project_status_types"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/project_status_types"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/project_status_types")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/project_status_types') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/project_status_types";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/project_status_types \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/project_status_types \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/project_status_types
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/project_status_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()
GET Get a statistics data for rejection reasons
{{baseUrl}}/overview/rejection_reasons
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/overview/rejection_reasons");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/overview/rejection_reasons" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/overview/rejection_reasons"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/overview/rejection_reasons"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/overview/rejection_reasons");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/overview/rejection_reasons"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/overview/rejection_reasons HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/overview/rejection_reasons")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/overview/rejection_reasons"))
    .header("x-auth-token", "{{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}}/overview/rejection_reasons")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/overview/rejection_reasons")
  .header("x-auth-token", "{{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}}/overview/rejection_reasons');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/overview/rejection_reasons',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/overview/rejection_reasons';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/overview/rejection_reasons',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/overview/rejection_reasons")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/overview/rejection_reasons',
  headers: {
    'x-auth-token': '{{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}}/overview/rejection_reasons',
  headers: {'x-auth-token': '{{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}}/overview/rejection_reasons');

req.headers({
  'x-auth-token': '{{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}}/overview/rejection_reasons',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/overview/rejection_reasons';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/overview/rejection_reasons"]
                                                       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}}/overview/rejection_reasons" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/overview/rejection_reasons",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/overview/rejection_reasons', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/overview/rejection_reasons');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/overview/rejection_reasons');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/overview/rejection_reasons' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/overview/rejection_reasons' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/overview/rejection_reasons", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/overview/rejection_reasons"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/overview/rejection_reasons"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/overview/rejection_reasons")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/overview/rejection_reasons') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/overview/rejection_reasons";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/overview/rejection_reasons \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/overview/rejection_reasons \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/overview/rejection_reasons
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/overview/rejection_reasons")! 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 View list of report types
{{baseUrl}}/reports
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/reports");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/reports")
require "http/client"

url = "{{baseUrl}}/reports"

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}}/reports"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/reports");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/reports"

	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/reports HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/reports")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/reports"))
    .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}}/reports")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/reports")
  .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}}/reports');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/reports'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/reports';
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}}/reports',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/reports")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/reports',
  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}}/reports'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/reports');

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}}/reports'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/reports';
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}}/reports"]
                                                       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}}/reports" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/reports",
  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}}/reports');

echo $response->getBody();
setUrl('{{baseUrl}}/reports');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/reports');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/reports' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/reports' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/reports")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/reports"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/reports"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/reports")

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/reports') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/reports";

    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}}/reports
http GET {{baseUrl}}/reports
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/reports
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/reports")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET Get a list of roles
{{baseUrl}}/roles
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/roles");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/roles" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/roles"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/roles"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/roles");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/roles"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/roles HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/roles")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/roles"))
    .header("x-auth-token", "{{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}}/roles")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/roles")
  .header("x-auth-token", "{{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}}/roles');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/roles',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/roles';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/roles',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/roles")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/roles',
  headers: {
    'x-auth-token': '{{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}}/roles',
  headers: {'x-auth-token': '{{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}}/roles');

req.headers({
  'x-auth-token': '{{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}}/roles',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/roles';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/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}}/roles" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/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 => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/roles', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/roles');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/roles');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/roles' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/roles' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/roles", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/roles"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/roles"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/roles")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/roles') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/roles";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/roles \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/roles \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/roles
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/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()
POST Add new stock_locations
{{baseUrl}}/stock_locations
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "name": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/stock_locations");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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/post "{{baseUrl}}/stock_locations" {:headers {:x-auth-token "{{apiKey}}"}
                                                            :content-type :json
                                                            :form-params {:name ""}})
require "http/client"

url = "{{baseUrl}}/stock_locations"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\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}}/stock_locations"),
    Headers =
    {
        { "x-auth-token", "{{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}}/stock_locations");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{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}}/stock_locations"

	payload := strings.NewReader("{\n  \"name\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/stock_locations HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 16

{
  "name": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/stock_locations")
  .setHeader("x-auth-token", "{{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}}/stock_locations"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", 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}}/stock_locations")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/stock_locations")
  .header("x-auth-token", "{{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('POST', '{{baseUrl}}/stock_locations');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/stock_locations',
  headers: {'x-auth-token': '{{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}}/stock_locations';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{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}}/stock_locations',
  method: 'POST',
  headers: {
    'x-auth-token': '{{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}}/stock_locations")
  .post(body)
  .addHeader("x-auth-token", "{{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/stock_locations',
  headers: {
    'x-auth-token': '{{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: 'POST',
  url: '{{baseUrl}}/stock_locations',
  headers: {'x-auth-token': '{{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('POST', '{{baseUrl}}/stock_locations');

req.headers({
  'x-auth-token': '{{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: 'POST',
  url: '{{baseUrl}}/stock_locations',
  headers: {'x-auth-token': '{{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}}/stock_locations';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{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 = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"name": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/stock_locations"]
                                                       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}}/stock_locations" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"name\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/stock_locations",
  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([
    'name' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/stock_locations', [
  'body' => '{
  "name": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/stock_locations');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{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}}/stock_locations');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/stock_locations' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "name": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/stock_locations' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "name": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"name\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/stock_locations", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/stock_locations"

payload = { "name": "" }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/stock_locations"

payload <- "{\n  \"name\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/stock_locations")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{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.post('/baseUrl/stock_locations') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\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}}/stock_locations";

    let payload = json!({"name": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/stock_locations \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "name": ""
}'
echo '{
  "name": ""
}' |  \
  http POST {{baseUrl}}/stock_locations \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "name": ""\n}' \
  --output-document \
  - {{baseUrl}}/stock_locations
import Foundation

let headers = [
  "x-auth-token": "{{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}}/stock_locations")! 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 Delete location
{{baseUrl}}/stock_locations/:location_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

location_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/stock_locations/:location_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/stock_locations/:location_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/stock_locations/:location_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/stock_locations/:location_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/stock_locations/:location_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/stock_locations/:location_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/stock_locations/:location_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/stock_locations/:location_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/stock_locations/:location_id"))
    .header("x-auth-token", "{{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}}/stock_locations/:location_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/stock_locations/:location_id")
  .header("x-auth-token", "{{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}}/stock_locations/:location_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/stock_locations/:location_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/stock_locations/:location_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/stock_locations/:location_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/stock_locations/:location_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/stock_locations/:location_id',
  headers: {
    'x-auth-token': '{{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}}/stock_locations/:location_id',
  headers: {'x-auth-token': '{{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}}/stock_locations/:location_id');

req.headers({
  'x-auth-token': '{{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}}/stock_locations/:location_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/stock_locations/:location_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/stock_locations/:location_id"]
                                                       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}}/stock_locations/:location_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/stock_locations/:location_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/stock_locations/:location_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/stock_locations/:location_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/stock_locations/:location_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/stock_locations/:location_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/stock_locations/:location_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/stock_locations/:location_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/stock_locations/:location_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/stock_locations/:location_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/stock_locations/:location_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/stock_locations/:location_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/stock_locations/:location_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/stock_locations/:location_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/stock_locations/:location_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/stock_locations/:location_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/stock_locations/:location_id")! 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()
PUT Edit location
{{baseUrl}}/stock_locations/:location_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

location_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/stock_locations/:location_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/stock_locations/:location_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/stock_locations/:location_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/stock_locations/:location_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/stock_locations/:location_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/stock_locations/:location_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/stock_locations/:location_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/stock_locations/:location_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/stock_locations/:location_id"))
    .header("x-auth-token", "{{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}}/stock_locations/:location_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/stock_locations/:location_id")
  .header("x-auth-token", "{{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}}/stock_locations/:location_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/stock_locations/:location_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/stock_locations/:location_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/stock_locations/:location_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/stock_locations/:location_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/stock_locations/:location_id',
  headers: {
    'x-auth-token': '{{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}}/stock_locations/:location_id',
  headers: {'x-auth-token': '{{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}}/stock_locations/:location_id');

req.headers({
  'x-auth-token': '{{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}}/stock_locations/:location_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/stock_locations/:location_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/stock_locations/:location_id"]
                                                       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}}/stock_locations/:location_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/stock_locations/:location_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/stock_locations/:location_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/stock_locations/:location_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/stock_locations/:location_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/stock_locations/:location_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/stock_locations/:location_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/stock_locations/:location_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/stock_locations/:location_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/stock_locations/:location_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/stock_locations/:location_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/stock_locations/:location_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/stock_locations/:location_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/stock_locations/:location_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/stock_locations/:location_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/stock_locations/:location_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/stock_locations/:location_id")! 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()
GET List stock_locations
{{baseUrl}}/stock_locations
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/stock_locations");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/stock_locations" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/stock_locations"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/stock_locations"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/stock_locations");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/stock_locations"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/stock_locations HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/stock_locations")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/stock_locations"))
    .header("x-auth-token", "{{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}}/stock_locations")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/stock_locations")
  .header("x-auth-token", "{{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}}/stock_locations');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/stock_locations',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/stock_locations';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/stock_locations',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/stock_locations")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/stock_locations',
  headers: {
    'x-auth-token': '{{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}}/stock_locations',
  headers: {'x-auth-token': '{{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}}/stock_locations');

req.headers({
  'x-auth-token': '{{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}}/stock_locations',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/stock_locations';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/stock_locations"]
                                                       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}}/stock_locations" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/stock_locations",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/stock_locations', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/stock_locations');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/stock_locations');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/stock_locations' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/stock_locations' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/stock_locations", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/stock_locations"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/stock_locations"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/stock_locations")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/stock_locations') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/stock_locations";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/stock_locations \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/stock_locations \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/stock_locations
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/stock_locations")! 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 View single location
{{baseUrl}}/stock_locations/:location_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

location_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/stock_locations/:location_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/stock_locations/:location_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/stock_locations/:location_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/stock_locations/:location_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/stock_locations/:location_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/stock_locations/:location_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/stock_locations/:location_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/stock_locations/:location_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/stock_locations/:location_id"))
    .header("x-auth-token", "{{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}}/stock_locations/:location_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/stock_locations/:location_id")
  .header("x-auth-token", "{{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}}/stock_locations/:location_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/stock_locations/:location_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/stock_locations/:location_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/stock_locations/:location_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/stock_locations/:location_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/stock_locations/:location_id',
  headers: {
    'x-auth-token': '{{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}}/stock_locations/:location_id',
  headers: {'x-auth-token': '{{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}}/stock_locations/:location_id');

req.headers({
  'x-auth-token': '{{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}}/stock_locations/:location_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/stock_locations/:location_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/stock_locations/:location_id"]
                                                       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}}/stock_locations/:location_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/stock_locations/:location_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/stock_locations/:location_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/stock_locations/:location_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/stock_locations/:location_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/stock_locations/:location_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/stock_locations/:location_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/stock_locations/:location_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/stock_locations/:location_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/stock_locations/:location_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/stock_locations/:location_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/stock_locations/:location_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/stock_locations/:location_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/stock_locations/:location_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/stock_locations/:location_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/stock_locations/:location_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/stock_locations/:location_id")! 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 new time entry
{{baseUrl}}/time_entries
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entries");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/time_entries" {:headers {:x-auth-token "{{apiKey}}"}
                                                         :content-type :json
                                                         :form-params {:form_id ""
                                                                       :from_time ""
                                                                       :is_all_day false
                                                                       :project_id ""
                                                                       :sum 0
                                                                       :time_entry_type_id ""
                                                                       :to_time ""
                                                                       :user_id ""}})
require "http/client"

url = "{{baseUrl}}/time_entries"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\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}}/time_entries"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\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}}/time_entries");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entries"

	payload := strings.NewReader("{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/time_entries HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 155

{
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/time_entries")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entries"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\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  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/time_entries")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/time_entries")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  form_id: '',
  from_time: '',
  is_all_day: false,
  project_id: '',
  sum: 0,
  time_entry_type_id: '',
  to_time: '',
  user_id: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/time_entries');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/time_entries',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    form_id: '',
    from_time: '',
    is_all_day: false,
    project_id: '',
    sum: 0,
    time_entry_type_id: '',
    to_time: '',
    user_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entries';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"form_id":"","from_time":"","is_all_day":false,"project_id":"","sum":0,"time_entry_type_id":"","to_time":"","user_id":""}'
};

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}}/time_entries',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "form_id": "",\n  "from_time": "",\n  "is_all_day": false,\n  "project_id": "",\n  "sum": 0,\n  "time_entry_type_id": "",\n  "to_time": "",\n  "user_id": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/time_entries")
  .post(body)
  .addHeader("x-auth-token", "{{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/time_entries',
  headers: {
    'x-auth-token': '{{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({
  form_id: '',
  from_time: '',
  is_all_day: false,
  project_id: '',
  sum: 0,
  time_entry_type_id: '',
  to_time: '',
  user_id: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/time_entries',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    form_id: '',
    from_time: '',
    is_all_day: false,
    project_id: '',
    sum: 0,
    time_entry_type_id: '',
    to_time: '',
    user_id: ''
  },
  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}}/time_entries');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  form_id: '',
  from_time: '',
  is_all_day: false,
  project_id: '',
  sum: 0,
  time_entry_type_id: '',
  to_time: '',
  user_id: ''
});

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}}/time_entries',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    form_id: '',
    from_time: '',
    is_all_day: false,
    project_id: '',
    sum: 0,
    time_entry_type_id: '',
    to_time: '',
    user_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entries';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"form_id":"","from_time":"","is_all_day":false,"project_id":"","sum":0,"time_entry_type_id":"","to_time":"","user_id":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"form_id": @"",
                              @"from_time": @"",
                              @"is_all_day": @NO,
                              @"project_id": @"",
                              @"sum": @0,
                              @"time_entry_type_id": @"",
                              @"to_time": @"",
                              @"user_id": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entries"]
                                                       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}}/time_entries" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entries",
  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([
    'form_id' => '',
    'from_time' => '',
    'is_all_day' => null,
    'project_id' => '',
    'sum' => 0,
    'time_entry_type_id' => '',
    'to_time' => '',
    'user_id' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/time_entries', [
  'body' => '{
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entries');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'form_id' => '',
  'from_time' => '',
  'is_all_day' => null,
  'project_id' => '',
  'sum' => 0,
  'time_entry_type_id' => '',
  'to_time' => '',
  'user_id' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'form_id' => '',
  'from_time' => '',
  'is_all_day' => null,
  'project_id' => '',
  'sum' => 0,
  'time_entry_type_id' => '',
  'to_time' => '',
  'user_id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/time_entries');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entries' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entries' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/time_entries", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entries"

payload = {
    "form_id": "",
    "from_time": "",
    "is_all_day": False,
    "project_id": "",
    "sum": 0,
    "time_entry_type_id": "",
    "to_time": "",
    "user_id": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entries"

payload <- "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entries")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\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/time_entries') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entries";

    let payload = json!({
        "form_id": "",
        "from_time": "",
        "is_all_day": false,
        "project_id": "",
        "sum": 0,
        "time_entry_type_id": "",
        "to_time": "",
        "user_id": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entries \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
}'
echo '{
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
}' |  \
  http POST {{baseUrl}}/time_entries \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "form_id": "",\n  "from_time": "",\n  "is_all_day": false,\n  "project_id": "",\n  "sum": 0,\n  "time_entry_type_id": "",\n  "to_time": "",\n  "user_id": ""\n}' \
  --output-document \
  - {{baseUrl}}/time_entries
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entries")! 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 Delete time entry
{{baseUrl}}/time_entries/:time_entry_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

time_entry_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entries/:time_entry_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/time_entries/:time_entry_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entries/:time_entry_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entries/:time_entry_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entries/:time_entry_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entries/:time_entry_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/time_entries/:time_entry_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/time_entries/:time_entry_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entries/:time_entry_id"))
    .header("x-auth-token", "{{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}}/time_entries/:time_entry_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/time_entries/:time_entry_id")
  .header("x-auth-token", "{{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}}/time_entries/:time_entry_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/time_entries/:time_entry_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entries/:time_entry_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/time_entries/:time_entry_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entries/:time_entry_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entries/:time_entry_id',
  headers: {
    'x-auth-token': '{{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}}/time_entries/:time_entry_id',
  headers: {'x-auth-token': '{{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}}/time_entries/:time_entry_id');

req.headers({
  'x-auth-token': '{{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}}/time_entries/:time_entry_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entries/:time_entry_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entries/:time_entry_id"]
                                                       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}}/time_entries/:time_entry_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entries/:time_entry_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/time_entries/:time_entry_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entries/:time_entry_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entries/:time_entry_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entries/:time_entry_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entries/:time_entry_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/time_entries/:time_entry_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entries/:time_entry_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entries/:time_entry_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entries/:time_entry_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/time_entries/:time_entry_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entries/:time_entry_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entries/:time_entry_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/time_entries/:time_entry_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entries/:time_entry_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entries/:time_entry_id")! 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()
PUT Edit time entry
{{baseUrl}}/time_entries/:time_entry_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

time_entry_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entries/:time_entry_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/time_entries/:time_entry_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entries/:time_entry_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entries/:time_entry_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entries/:time_entry_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entries/:time_entry_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/time_entries/:time_entry_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/time_entries/:time_entry_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entries/:time_entry_id"))
    .header("x-auth-token", "{{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}}/time_entries/:time_entry_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/time_entries/:time_entry_id")
  .header("x-auth-token", "{{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}}/time_entries/:time_entry_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/time_entries/:time_entry_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entries/:time_entry_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/time_entries/:time_entry_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entries/:time_entry_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entries/:time_entry_id',
  headers: {
    'x-auth-token': '{{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}}/time_entries/:time_entry_id',
  headers: {'x-auth-token': '{{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}}/time_entries/:time_entry_id');

req.headers({
  'x-auth-token': '{{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}}/time_entries/:time_entry_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entries/:time_entry_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entries/:time_entry_id"]
                                                       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}}/time_entries/:time_entry_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entries/:time_entry_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/time_entries/:time_entry_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entries/:time_entry_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entries/:time_entry_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entries/:time_entry_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entries/:time_entry_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/time_entries/:time_entry_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entries/:time_entry_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entries/:time_entry_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entries/:time_entry_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/time_entries/:time_entry_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entries/:time_entry_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entries/:time_entry_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/time_entries/:time_entry_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entries/:time_entry_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entries/:time_entry_id")! 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()
GET List time entries
{{baseUrl}}/time_entries
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entries");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/time_entries" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entries"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entries"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entries");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entries"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/time_entries HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/time_entries")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entries"))
    .header("x-auth-token", "{{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}}/time_entries")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/time_entries")
  .header("x-auth-token", "{{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}}/time_entries');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/time_entries',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entries';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/time_entries',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entries")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entries',
  headers: {
    'x-auth-token': '{{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}}/time_entries',
  headers: {'x-auth-token': '{{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}}/time_entries');

req.headers({
  'x-auth-token': '{{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}}/time_entries',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entries';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entries"]
                                                       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}}/time_entries" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entries",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/time_entries', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entries');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entries');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entries' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entries' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/time_entries", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entries"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entries"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entries")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/time_entries') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entries";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entries \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/time_entries \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entries
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entries")! 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 View time entry
{{baseUrl}}/time_entries/:time_entry_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

time_entry_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entries/:time_entry_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/time_entries/:time_entry_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entries/:time_entry_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entries/:time_entry_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entries/:time_entry_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entries/:time_entry_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/time_entries/:time_entry_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/time_entries/:time_entry_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entries/:time_entry_id"))
    .header("x-auth-token", "{{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}}/time_entries/:time_entry_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/time_entries/:time_entry_id")
  .header("x-auth-token", "{{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}}/time_entries/:time_entry_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/time_entries/:time_entry_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entries/:time_entry_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/time_entries/:time_entry_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entries/:time_entry_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entries/:time_entry_id',
  headers: {
    'x-auth-token': '{{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}}/time_entries/:time_entry_id',
  headers: {'x-auth-token': '{{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}}/time_entries/:time_entry_id');

req.headers({
  'x-auth-token': '{{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}}/time_entries/:time_entry_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entries/:time_entry_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entries/:time_entry_id"]
                                                       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}}/time_entries/:time_entry_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entries/:time_entry_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/time_entries/:time_entry_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entries/:time_entry_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entries/:time_entry_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entries/:time_entry_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entries/:time_entry_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/time_entries/:time_entry_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entries/:time_entry_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entries/:time_entry_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entries/:time_entry_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/time_entries/:time_entry_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entries/:time_entry_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entries/:time_entry_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/time_entries/:time_entry_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entries/:time_entry_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entries/:time_entry_id")! 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 possible time entry intervals
{{baseUrl}}/time_entry_intervals
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_intervals");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/time_entry_intervals" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_intervals"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_intervals"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_intervals");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_intervals"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/time_entry_intervals HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/time_entry_intervals")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_intervals"))
    .header("x-auth-token", "{{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}}/time_entry_intervals")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/time_entry_intervals")
  .header("x-auth-token", "{{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}}/time_entry_intervals');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/time_entry_intervals',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_intervals';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/time_entry_intervals',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_intervals")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_intervals',
  headers: {
    'x-auth-token': '{{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}}/time_entry_intervals',
  headers: {'x-auth-token': '{{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}}/time_entry_intervals');

req.headers({
  'x-auth-token': '{{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}}/time_entry_intervals',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_intervals';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_intervals"]
                                                       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}}/time_entry_intervals" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_intervals",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/time_entry_intervals', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_intervals');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_intervals');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_intervals' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_intervals' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/time_entry_intervals", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_intervals"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_intervals"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_intervals")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/time_entry_intervals') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_intervals";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_intervals \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/time_entry_intervals \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_intervals
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_intervals")! 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 View time entry interval
{{baseUrl}}/time_entry_intervals/:time_entry_interval_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

time_entry_interval_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_intervals/:time_entry_interval_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/time_entry_intervals/:time_entry_interval_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_intervals/:time_entry_interval_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_intervals/:time_entry_interval_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_intervals/:time_entry_interval_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_intervals/:time_entry_interval_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/time_entry_intervals/:time_entry_interval_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/time_entry_intervals/:time_entry_interval_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_intervals/:time_entry_interval_id"))
    .header("x-auth-token", "{{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}}/time_entry_intervals/:time_entry_interval_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/time_entry_intervals/:time_entry_interval_id")
  .header("x-auth-token", "{{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}}/time_entry_intervals/:time_entry_interval_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/time_entry_intervals/:time_entry_interval_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_intervals/:time_entry_interval_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/time_entry_intervals/:time_entry_interval_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_intervals/:time_entry_interval_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_intervals/:time_entry_interval_id',
  headers: {
    'x-auth-token': '{{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}}/time_entry_intervals/:time_entry_interval_id',
  headers: {'x-auth-token': '{{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}}/time_entry_intervals/:time_entry_interval_id');

req.headers({
  'x-auth-token': '{{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}}/time_entry_intervals/:time_entry_interval_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_intervals/:time_entry_interval_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_intervals/:time_entry_interval_id"]
                                                       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}}/time_entry_intervals/:time_entry_interval_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_intervals/:time_entry_interval_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/time_entry_intervals/:time_entry_interval_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_intervals/:time_entry_interval_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_intervals/:time_entry_interval_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_intervals/:time_entry_interval_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_intervals/:time_entry_interval_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/time_entry_intervals/:time_entry_interval_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_intervals/:time_entry_interval_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_intervals/:time_entry_interval_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_intervals/:time_entry_interval_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/time_entry_intervals/:time_entry_interval_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_intervals/:time_entry_interval_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_intervals/:time_entry_interval_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/time_entry_intervals/:time_entry_interval_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_intervals/:time_entry_interval_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_intervals/:time_entry_interval_id")! 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 Delete time entry rate
{{baseUrl}}/time_entry_rates/:time_entry_rate_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

time_entry_rate_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_rates/:time_entry_rate_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/time_entry_rates/:time_entry_rate_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_rates/:time_entry_rate_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_rates/:time_entry_rate_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_rates/:time_entry_rate_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_rates/:time_entry_rate_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/time_entry_rates/:time_entry_rate_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/time_entry_rates/:time_entry_rate_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_rates/:time_entry_rate_id"))
    .header("x-auth-token", "{{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}}/time_entry_rates/:time_entry_rate_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/time_entry_rates/:time_entry_rate_id")
  .header("x-auth-token", "{{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}}/time_entry_rates/:time_entry_rate_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/time_entry_rates/:time_entry_rate_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_rates/:time_entry_rate_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/time_entry_rates/:time_entry_rate_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_rates/:time_entry_rate_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_rates/:time_entry_rate_id',
  headers: {
    'x-auth-token': '{{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}}/time_entry_rates/:time_entry_rate_id',
  headers: {'x-auth-token': '{{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}}/time_entry_rates/:time_entry_rate_id');

req.headers({
  'x-auth-token': '{{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}}/time_entry_rates/:time_entry_rate_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_rates/:time_entry_rate_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_rates/:time_entry_rate_id"]
                                                       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}}/time_entry_rates/:time_entry_rate_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_rates/:time_entry_rate_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/time_entry_rates/:time_entry_rate_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_rates/:time_entry_rate_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_rates/:time_entry_rate_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_rates/:time_entry_rate_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_rates/:time_entry_rate_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/time_entry_rates/:time_entry_rate_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_rates/:time_entry_rate_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_rates/:time_entry_rate_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_rates/:time_entry_rate_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/time_entry_rates/:time_entry_rate_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_rates/:time_entry_rate_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_rates/:time_entry_rate_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/time_entry_rates/:time_entry_rate_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_rates/:time_entry_rate_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_rates/:time_entry_rate_id")! 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()
POST Add new time entry rate
{{baseUrl}}/time_entry_rates
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_rates");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/time_entry_rates" {:headers {:x-auth-token "{{apiKey}}"}
                                                             :content-type :json
                                                             :form-params {:form_id ""
                                                                           :from_time ""
                                                                           :is_all_day false
                                                                           :project_id ""
                                                                           :sum 0
                                                                           :time_entry_type_id ""
                                                                           :to_time ""
                                                                           :user_id ""}})
require "http/client"

url = "{{baseUrl}}/time_entry_rates"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\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}}/time_entry_rates"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\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}}/time_entry_rates");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_rates"

	payload := strings.NewReader("{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/time_entry_rates HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 155

{
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/time_entry_rates")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_rates"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\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  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/time_entry_rates")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/time_entry_rates")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  form_id: '',
  from_time: '',
  is_all_day: false,
  project_id: '',
  sum: 0,
  time_entry_type_id: '',
  to_time: '',
  user_id: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/time_entry_rates');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/time_entry_rates',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    form_id: '',
    from_time: '',
    is_all_day: false,
    project_id: '',
    sum: 0,
    time_entry_type_id: '',
    to_time: '',
    user_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_rates';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"form_id":"","from_time":"","is_all_day":false,"project_id":"","sum":0,"time_entry_type_id":"","to_time":"","user_id":""}'
};

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}}/time_entry_rates',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "form_id": "",\n  "from_time": "",\n  "is_all_day": false,\n  "project_id": "",\n  "sum": 0,\n  "time_entry_type_id": "",\n  "to_time": "",\n  "user_id": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_rates")
  .post(body)
  .addHeader("x-auth-token", "{{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/time_entry_rates',
  headers: {
    'x-auth-token': '{{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({
  form_id: '',
  from_time: '',
  is_all_day: false,
  project_id: '',
  sum: 0,
  time_entry_type_id: '',
  to_time: '',
  user_id: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/time_entry_rates',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    form_id: '',
    from_time: '',
    is_all_day: false,
    project_id: '',
    sum: 0,
    time_entry_type_id: '',
    to_time: '',
    user_id: ''
  },
  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}}/time_entry_rates');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  form_id: '',
  from_time: '',
  is_all_day: false,
  project_id: '',
  sum: 0,
  time_entry_type_id: '',
  to_time: '',
  user_id: ''
});

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}}/time_entry_rates',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    form_id: '',
    from_time: '',
    is_all_day: false,
    project_id: '',
    sum: 0,
    time_entry_type_id: '',
    to_time: '',
    user_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_rates';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"form_id":"","from_time":"","is_all_day":false,"project_id":"","sum":0,"time_entry_type_id":"","to_time":"","user_id":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"form_id": @"",
                              @"from_time": @"",
                              @"is_all_day": @NO,
                              @"project_id": @"",
                              @"sum": @0,
                              @"time_entry_type_id": @"",
                              @"to_time": @"",
                              @"user_id": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_rates"]
                                                       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}}/time_entry_rates" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_rates",
  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([
    'form_id' => '',
    'from_time' => '',
    'is_all_day' => null,
    'project_id' => '',
    'sum' => 0,
    'time_entry_type_id' => '',
    'to_time' => '',
    'user_id' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/time_entry_rates', [
  'body' => '{
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_rates');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'form_id' => '',
  'from_time' => '',
  'is_all_day' => null,
  'project_id' => '',
  'sum' => 0,
  'time_entry_type_id' => '',
  'to_time' => '',
  'user_id' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'form_id' => '',
  'from_time' => '',
  'is_all_day' => null,
  'project_id' => '',
  'sum' => 0,
  'time_entry_type_id' => '',
  'to_time' => '',
  'user_id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/time_entry_rates');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_rates' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_rates' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/time_entry_rates", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_rates"

payload = {
    "form_id": "",
    "from_time": "",
    "is_all_day": False,
    "project_id": "",
    "sum": 0,
    "time_entry_type_id": "",
    "to_time": "",
    "user_id": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_rates"

payload <- "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_rates")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\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/time_entry_rates') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"form_id\": \"\",\n  \"from_time\": \"\",\n  \"is_all_day\": false,\n  \"project_id\": \"\",\n  \"sum\": 0,\n  \"time_entry_type_id\": \"\",\n  \"to_time\": \"\",\n  \"user_id\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_rates";

    let payload = json!({
        "form_id": "",
        "from_time": "",
        "is_all_day": false,
        "project_id": "",
        "sum": 0,
        "time_entry_type_id": "",
        "to_time": "",
        "user_id": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_rates \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
}'
echo '{
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
}' |  \
  http POST {{baseUrl}}/time_entry_rates \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "form_id": "",\n  "from_time": "",\n  "is_all_day": false,\n  "project_id": "",\n  "sum": 0,\n  "time_entry_type_id": "",\n  "to_time": "",\n  "user_id": ""\n}' \
  --output-document \
  - {{baseUrl}}/time_entry_rates
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "form_id": "",
  "from_time": "",
  "is_all_day": false,
  "project_id": "",
  "sum": 0,
  "time_entry_type_id": "",
  "to_time": "",
  "user_id": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_rates")! 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 Edit time entry rate
{{baseUrl}}/time_entry_rates/:time_entry_rate_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

time_entry_rate_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_rates/:time_entry_rate_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/time_entry_rates/:time_entry_rate_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_rates/:time_entry_rate_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_rates/:time_entry_rate_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_rates/:time_entry_rate_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_rates/:time_entry_rate_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/time_entry_rates/:time_entry_rate_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/time_entry_rates/:time_entry_rate_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_rates/:time_entry_rate_id"))
    .header("x-auth-token", "{{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}}/time_entry_rates/:time_entry_rate_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/time_entry_rates/:time_entry_rate_id")
  .header("x-auth-token", "{{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}}/time_entry_rates/:time_entry_rate_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/time_entry_rates/:time_entry_rate_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_rates/:time_entry_rate_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/time_entry_rates/:time_entry_rate_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_rates/:time_entry_rate_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_rates/:time_entry_rate_id',
  headers: {
    'x-auth-token': '{{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}}/time_entry_rates/:time_entry_rate_id',
  headers: {'x-auth-token': '{{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}}/time_entry_rates/:time_entry_rate_id');

req.headers({
  'x-auth-token': '{{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}}/time_entry_rates/:time_entry_rate_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_rates/:time_entry_rate_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_rates/:time_entry_rate_id"]
                                                       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}}/time_entry_rates/:time_entry_rate_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_rates/:time_entry_rate_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/time_entry_rates/:time_entry_rate_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_rates/:time_entry_rate_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_rates/:time_entry_rate_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_rates/:time_entry_rate_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_rates/:time_entry_rate_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/time_entry_rates/:time_entry_rate_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_rates/:time_entry_rate_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_rates/:time_entry_rate_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_rates/:time_entry_rate_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/time_entry_rates/:time_entry_rate_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_rates/:time_entry_rate_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_rates/:time_entry_rate_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/time_entry_rates/:time_entry_rate_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_rates/:time_entry_rate_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_rates/:time_entry_rate_id")! 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()
GET List time entry rates
{{baseUrl}}/time_entry_rates
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_rates");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/time_entry_rates" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_rates"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_rates"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_rates");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_rates"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/time_entry_rates HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/time_entry_rates")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_rates"))
    .header("x-auth-token", "{{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}}/time_entry_rates")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/time_entry_rates")
  .header("x-auth-token", "{{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}}/time_entry_rates');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/time_entry_rates',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_rates';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/time_entry_rates',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_rates")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_rates',
  headers: {
    'x-auth-token': '{{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}}/time_entry_rates',
  headers: {'x-auth-token': '{{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}}/time_entry_rates');

req.headers({
  'x-auth-token': '{{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}}/time_entry_rates',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_rates';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_rates"]
                                                       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}}/time_entry_rates" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_rates",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/time_entry_rates', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_rates');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_rates');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_rates' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_rates' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/time_entry_rates", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_rates"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_rates"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_rates")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/time_entry_rates') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_rates";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_rates \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/time_entry_rates \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_rates
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_rates")! 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 View time entry rate
{{baseUrl}}/time_entry_rates/:time_entry_rate_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

time_entry_rate_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_rates/:time_entry_rate_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/time_entry_rates/:time_entry_rate_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_rates/:time_entry_rate_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_rates/:time_entry_rate_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_rates/:time_entry_rate_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_rates/:time_entry_rate_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/time_entry_rates/:time_entry_rate_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/time_entry_rates/:time_entry_rate_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_rates/:time_entry_rate_id"))
    .header("x-auth-token", "{{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}}/time_entry_rates/:time_entry_rate_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/time_entry_rates/:time_entry_rate_id")
  .header("x-auth-token", "{{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}}/time_entry_rates/:time_entry_rate_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/time_entry_rates/:time_entry_rate_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_rates/:time_entry_rate_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/time_entry_rates/:time_entry_rate_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_rates/:time_entry_rate_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_rates/:time_entry_rate_id',
  headers: {
    'x-auth-token': '{{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}}/time_entry_rates/:time_entry_rate_id',
  headers: {'x-auth-token': '{{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}}/time_entry_rates/:time_entry_rate_id');

req.headers({
  'x-auth-token': '{{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}}/time_entry_rates/:time_entry_rate_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_rates/:time_entry_rate_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_rates/:time_entry_rate_id"]
                                                       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}}/time_entry_rates/:time_entry_rate_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_rates/:time_entry_rate_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/time_entry_rates/:time_entry_rate_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_rates/:time_entry_rate_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_rates/:time_entry_rate_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_rates/:time_entry_rate_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_rates/:time_entry_rate_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/time_entry_rates/:time_entry_rate_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_rates/:time_entry_rate_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_rates/:time_entry_rate_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_rates/:time_entry_rate_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/time_entry_rates/:time_entry_rate_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_rates/:time_entry_rate_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_rates/:time_entry_rate_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/time_entry_rates/:time_entry_rate_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_rates/:time_entry_rate_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_rates/:time_entry_rate_id")! 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 time entry rule groups
{{baseUrl}}/time_entry_rule_groups
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_rule_groups");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/time_entry_rule_groups" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_rule_groups"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_rule_groups"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_rule_groups");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_rule_groups"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/time_entry_rule_groups HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/time_entry_rule_groups")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_rule_groups"))
    .header("x-auth-token", "{{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}}/time_entry_rule_groups")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/time_entry_rule_groups")
  .header("x-auth-token", "{{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}}/time_entry_rule_groups');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/time_entry_rule_groups',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_rule_groups';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/time_entry_rule_groups',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_rule_groups")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_rule_groups',
  headers: {
    'x-auth-token': '{{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}}/time_entry_rule_groups',
  headers: {'x-auth-token': '{{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}}/time_entry_rule_groups');

req.headers({
  'x-auth-token': '{{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}}/time_entry_rule_groups',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_rule_groups';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_rule_groups"]
                                                       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}}/time_entry_rule_groups" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_rule_groups",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/time_entry_rule_groups', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_rule_groups');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_rule_groups');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_rule_groups' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_rule_groups' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/time_entry_rule_groups", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_rule_groups"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_rule_groups"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_rule_groups")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/time_entry_rule_groups') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_rule_groups";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_rule_groups \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/time_entry_rule_groups \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_rule_groups
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_rule_groups")! 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 new time entry type
{{baseUrl}}/time_entry_types
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "description": "",
  "name": "",
  "time_entry_interval_id": "",
  "time_entry_value_type_id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_types");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/time_entry_types" {:headers {:x-auth-token "{{apiKey}}"}
                                                             :content-type :json
                                                             :form-params {:description ""
                                                                           :name ""
                                                                           :time_entry_interval_id ""
                                                                           :time_entry_value_type_id ""}})
require "http/client"

url = "{{baseUrl}}/time_entry_types"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\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}}/time_entry_types"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\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}}/time_entry_types");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_types"

	payload := strings.NewReader("{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/time_entry_types HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 103

{
  "description": "",
  "name": "",
  "time_entry_interval_id": "",
  "time_entry_value_type_id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/time_entry_types")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_types"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\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  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/time_entry_types")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/time_entry_types")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  description: '',
  name: '',
  time_entry_interval_id: '',
  time_entry_value_type_id: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/time_entry_types');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/time_entry_types',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    description: '',
    name: '',
    time_entry_interval_id: '',
    time_entry_value_type_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_types';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"description":"","name":"","time_entry_interval_id":"","time_entry_value_type_id":""}'
};

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}}/time_entry_types',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "description": "",\n  "name": "",\n  "time_entry_interval_id": "",\n  "time_entry_value_type_id": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_types")
  .post(body)
  .addHeader("x-auth-token", "{{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/time_entry_types',
  headers: {
    'x-auth-token': '{{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({
  description: '',
  name: '',
  time_entry_interval_id: '',
  time_entry_value_type_id: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/time_entry_types',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    description: '',
    name: '',
    time_entry_interval_id: '',
    time_entry_value_type_id: ''
  },
  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}}/time_entry_types');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  description: '',
  name: '',
  time_entry_interval_id: '',
  time_entry_value_type_id: ''
});

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}}/time_entry_types',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    description: '',
    name: '',
    time_entry_interval_id: '',
    time_entry_value_type_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_types';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"description":"","name":"","time_entry_interval_id":"","time_entry_value_type_id":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"description": @"",
                              @"name": @"",
                              @"time_entry_interval_id": @"",
                              @"time_entry_value_type_id": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_types"]
                                                       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}}/time_entry_types" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_types",
  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([
    'description' => '',
    'name' => '',
    'time_entry_interval_id' => '',
    'time_entry_value_type_id' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/time_entry_types', [
  'body' => '{
  "description": "",
  "name": "",
  "time_entry_interval_id": "",
  "time_entry_value_type_id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_types');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'description' => '',
  'name' => '',
  'time_entry_interval_id' => '',
  'time_entry_value_type_id' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'description' => '',
  'name' => '',
  'time_entry_interval_id' => '',
  'time_entry_value_type_id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/time_entry_types');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_types' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "description": "",
  "name": "",
  "time_entry_interval_id": "",
  "time_entry_value_type_id": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_types' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "description": "",
  "name": "",
  "time_entry_interval_id": "",
  "time_entry_value_type_id": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/time_entry_types", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_types"

payload = {
    "description": "",
    "name": "",
    "time_entry_interval_id": "",
    "time_entry_value_type_id": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_types"

payload <- "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_types")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\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/time_entry_types') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"description\": \"\",\n  \"name\": \"\",\n  \"time_entry_interval_id\": \"\",\n  \"time_entry_value_type_id\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_types";

    let payload = json!({
        "description": "",
        "name": "",
        "time_entry_interval_id": "",
        "time_entry_value_type_id": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_types \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "description": "",
  "name": "",
  "time_entry_interval_id": "",
  "time_entry_value_type_id": ""
}'
echo '{
  "description": "",
  "name": "",
  "time_entry_interval_id": "",
  "time_entry_value_type_id": ""
}' |  \
  http POST {{baseUrl}}/time_entry_types \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "description": "",\n  "name": "",\n  "time_entry_interval_id": "",\n  "time_entry_value_type_id": ""\n}' \
  --output-document \
  - {{baseUrl}}/time_entry_types
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "description": "",
  "name": "",
  "time_entry_interval_id": "",
  "time_entry_value_type_id": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_types")! 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 Bulk activate time entry types
{{baseUrl}}/time_entry_types/bulkActivate
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_types/bulkActivate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/time_entry_types/bulkActivate" {:headers {:x-auth-token "{{apiKey}}"}
                                                                          :content-type :json
                                                                          :form-params {:id []}})
require "http/client"

url = "{{baseUrl}}/time_entry_types/bulkActivate"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": []\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}}/time_entry_types/bulkActivate"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id\": []\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}}/time_entry_types/bulkActivate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_types/bulkActivate"

	payload := strings.NewReader("{\n  \"id\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/time_entry_types/bulkActivate HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/time_entry_types/bulkActivate")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_types/bulkActivate"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"id\": []\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\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/time_entry_types/bulkActivate")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/time_entry_types/bulkActivate")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/time_entry_types/bulkActivate');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/time_entry_types/bulkActivate',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_types/bulkActivate';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/time_entry_types/bulkActivate',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_types/bulkActivate")
  .post(body)
  .addHeader("x-auth-token", "{{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/time_entry_types/bulkActivate',
  headers: {
    'x-auth-token': '{{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: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/time_entry_types/bulkActivate',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {id: []},
  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}}/time_entry_types/bulkActivate');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: []
});

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}}/time_entry_types/bulkActivate',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_types/bulkActivate';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_types/bulkActivate"]
                                                       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}}/time_entry_types/bulkActivate" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_types/bulkActivate",
  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' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/time_entry_types/bulkActivate', [
  'body' => '{
  "id": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_types/bulkActivate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/time_entry_types/bulkActivate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_types/bulkActivate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_types/bulkActivate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": []\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/time_entry_types/bulkActivate", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_types/bulkActivate"

payload = { "id": [] }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_types/bulkActivate"

payload <- "{\n  \"id\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_types/bulkActivate")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/time_entry_types/bulkActivate') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"id\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_types/bulkActivate";

    let payload = json!({"id": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_types/bulkActivate \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http POST {{baseUrl}}/time_entry_types/bulkActivate \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/time_entry_types/bulkActivate
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_types/bulkActivate")! 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 Bulk deactivate time entry types
{{baseUrl}}/time_entry_types/bulkDeactivate
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_types/bulkDeactivate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/time_entry_types/bulkDeactivate" {:headers {:x-auth-token "{{apiKey}}"}
                                                                            :content-type :json
                                                                            :form-params {:id []}})
require "http/client"

url = "{{baseUrl}}/time_entry_types/bulkDeactivate"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": []\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}}/time_entry_types/bulkDeactivate"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id\": []\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}}/time_entry_types/bulkDeactivate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_types/bulkDeactivate"

	payload := strings.NewReader("{\n  \"id\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/time_entry_types/bulkDeactivate HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/time_entry_types/bulkDeactivate")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_types/bulkDeactivate"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"id\": []\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\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/time_entry_types/bulkDeactivate")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/time_entry_types/bulkDeactivate")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/time_entry_types/bulkDeactivate');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/time_entry_types/bulkDeactivate',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_types/bulkDeactivate';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/time_entry_types/bulkDeactivate',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_types/bulkDeactivate")
  .post(body)
  .addHeader("x-auth-token", "{{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/time_entry_types/bulkDeactivate',
  headers: {
    'x-auth-token': '{{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: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/time_entry_types/bulkDeactivate',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {id: []},
  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}}/time_entry_types/bulkDeactivate');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: []
});

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}}/time_entry_types/bulkDeactivate',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_types/bulkDeactivate';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_types/bulkDeactivate"]
                                                       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}}/time_entry_types/bulkDeactivate" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_types/bulkDeactivate",
  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' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/time_entry_types/bulkDeactivate', [
  'body' => '{
  "id": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_types/bulkDeactivate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/time_entry_types/bulkDeactivate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_types/bulkDeactivate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_types/bulkDeactivate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": []\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/time_entry_types/bulkDeactivate", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_types/bulkDeactivate"

payload = { "id": [] }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_types/bulkDeactivate"

payload <- "{\n  \"id\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_types/bulkDeactivate")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/time_entry_types/bulkDeactivate') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"id\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_types/bulkDeactivate";

    let payload = json!({"id": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_types/bulkDeactivate \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http POST {{baseUrl}}/time_entry_types/bulkDeactivate \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/time_entry_types/bulkDeactivate
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_types/bulkDeactivate")! 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 Bulk delete time entry types
{{baseUrl}}/time_entry_types/bulkDelete
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_types/bulkDelete");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/time_entry_types/bulkDelete" {:headers {:x-auth-token "{{apiKey}}"}
                                                                          :content-type :json
                                                                          :form-params {:id []}})
require "http/client"

url = "{{baseUrl}}/time_entry_types/bulkDelete"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": []\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}}/time_entry_types/bulkDelete"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id\": []\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}}/time_entry_types/bulkDelete");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_types/bulkDelete"

	payload := strings.NewReader("{\n  \"id\": []\n}")

	req, _ := http.NewRequest("DELETE", url, payload)

	req.Header.Add("x-auth-token", "{{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/time_entry_types/bulkDelete HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/time_entry_types/bulkDelete")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_types/bulkDelete"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("DELETE", HttpRequest.BodyPublishers.ofString("{\n  \"id\": []\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\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/time_entry_types/bulkDelete")
  .delete(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/time_entry_types/bulkDelete")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/time_entry_types/bulkDelete');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/time_entry_types/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_types/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/time_entry_types/bulkDelete',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_types/bulkDelete")
  .delete(body)
  .addHeader("x-auth-token", "{{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/time_entry_types/bulkDelete',
  headers: {
    'x-auth-token': '{{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: []}));
req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/time_entry_types/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {id: []},
  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}}/time_entry_types/bulkDelete');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: []
});

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}}/time_entry_types/bulkDelete',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_types/bulkDelete';
const options = {
  method: 'DELETE',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_types/bulkDelete"]
                                                       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}}/time_entry_types/bulkDelete" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": []\n}" in

Client.call ~headers ~body `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_types/bulkDelete",
  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([
    'id' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/time_entry_types/bulkDelete', [
  'body' => '{
  "id": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_types/bulkDelete');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/time_entry_types/bulkDelete');
$request->setRequestMethod('DELETE');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_types/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_types/bulkDelete' -Method DELETE -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": []\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("DELETE", "/baseUrl/time_entry_types/bulkDelete", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_types/bulkDelete"

payload = { "id": [] }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.delete(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_types/bulkDelete"

payload <- "{\n  \"id\": []\n}"

encode <- "json"

response <- VERB("DELETE", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_types/bulkDelete")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/time_entry_types/bulkDelete') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"id\": []\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}}/time_entry_types/bulkDelete";

    let payload = json!({"id": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_types/bulkDelete \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http DELETE {{baseUrl}}/time_entry_types/bulkDelete \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/time_entry_types/bulkDelete
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_types/bulkDelete")! 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 time entry type
{{baseUrl}}/time_entry_types/:time_entry_type_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

time_entry_type_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_types/:time_entry_type_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/time_entry_types/:time_entry_type_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_types/:time_entry_type_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_types/:time_entry_type_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_types/:time_entry_type_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_types/:time_entry_type_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/time_entry_types/:time_entry_type_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/time_entry_types/:time_entry_type_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_types/:time_entry_type_id"))
    .header("x-auth-token", "{{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}}/time_entry_types/:time_entry_type_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/time_entry_types/:time_entry_type_id")
  .header("x-auth-token", "{{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}}/time_entry_types/:time_entry_type_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/time_entry_types/:time_entry_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_types/:time_entry_type_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/time_entry_types/:time_entry_type_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_types/:time_entry_type_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_types/:time_entry_type_id',
  headers: {
    'x-auth-token': '{{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}}/time_entry_types/:time_entry_type_id',
  headers: {'x-auth-token': '{{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}}/time_entry_types/:time_entry_type_id');

req.headers({
  'x-auth-token': '{{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}}/time_entry_types/:time_entry_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_types/:time_entry_type_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_types/:time_entry_type_id"]
                                                       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}}/time_entry_types/:time_entry_type_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_types/:time_entry_type_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/time_entry_types/:time_entry_type_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_types/:time_entry_type_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_types/:time_entry_type_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_types/:time_entry_type_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_types/:time_entry_type_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/time_entry_types/:time_entry_type_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_types/:time_entry_type_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_types/:time_entry_type_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_types/:time_entry_type_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/time_entry_types/:time_entry_type_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_types/:time_entry_type_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_types/:time_entry_type_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/time_entry_types/:time_entry_type_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_types/:time_entry_type_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_types/:time_entry_type_id")! 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()
PUT Edit time entry type
{{baseUrl}}/time_entry_types/:time_entry_type_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

time_entry_type_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_types/:time_entry_type_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/time_entry_types/:time_entry_type_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_types/:time_entry_type_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_types/:time_entry_type_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_types/:time_entry_type_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_types/:time_entry_type_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/time_entry_types/:time_entry_type_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/time_entry_types/:time_entry_type_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_types/:time_entry_type_id"))
    .header("x-auth-token", "{{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}}/time_entry_types/:time_entry_type_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/time_entry_types/:time_entry_type_id")
  .header("x-auth-token", "{{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}}/time_entry_types/:time_entry_type_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/time_entry_types/:time_entry_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_types/:time_entry_type_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/time_entry_types/:time_entry_type_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_types/:time_entry_type_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_types/:time_entry_type_id',
  headers: {
    'x-auth-token': '{{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}}/time_entry_types/:time_entry_type_id',
  headers: {'x-auth-token': '{{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}}/time_entry_types/:time_entry_type_id');

req.headers({
  'x-auth-token': '{{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}}/time_entry_types/:time_entry_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_types/:time_entry_type_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_types/:time_entry_type_id"]
                                                       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}}/time_entry_types/:time_entry_type_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_types/:time_entry_type_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/time_entry_types/:time_entry_type_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_types/:time_entry_type_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_types/:time_entry_type_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_types/:time_entry_type_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_types/:time_entry_type_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/time_entry_types/:time_entry_type_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_types/:time_entry_type_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_types/:time_entry_type_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_types/:time_entry_type_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/time_entry_types/:time_entry_type_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_types/:time_entry_type_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_types/:time_entry_type_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/time_entry_types/:time_entry_type_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_types/:time_entry_type_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_types/:time_entry_type_id")! 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()
GET List time entries types
{{baseUrl}}/time_entry_types
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_types");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/time_entry_types" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_types"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_types"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_types");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_types"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/time_entry_types HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/time_entry_types")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_types"))
    .header("x-auth-token", "{{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}}/time_entry_types")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/time_entry_types")
  .header("x-auth-token", "{{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}}/time_entry_types');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/time_entry_types',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_types';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/time_entry_types',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_types")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_types',
  headers: {
    'x-auth-token': '{{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}}/time_entry_types',
  headers: {'x-auth-token': '{{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}}/time_entry_types');

req.headers({
  'x-auth-token': '{{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}}/time_entry_types',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_types';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_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}}/time_entry_types" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_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 => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/time_entry_types', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_types');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_types');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_types' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_types' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/time_entry_types", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_types"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_types"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_types")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/time_entry_types') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_types";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_types \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/time_entry_types \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_types
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_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()
GET View time entry type
{{baseUrl}}/time_entry_types/:time_entry_type_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

time_entry_type_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_types/:time_entry_type_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/time_entry_types/:time_entry_type_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_types/:time_entry_type_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_types/:time_entry_type_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_types/:time_entry_type_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_types/:time_entry_type_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/time_entry_types/:time_entry_type_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/time_entry_types/:time_entry_type_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_types/:time_entry_type_id"))
    .header("x-auth-token", "{{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}}/time_entry_types/:time_entry_type_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/time_entry_types/:time_entry_type_id")
  .header("x-auth-token", "{{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}}/time_entry_types/:time_entry_type_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/time_entry_types/:time_entry_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_types/:time_entry_type_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/time_entry_types/:time_entry_type_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_types/:time_entry_type_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_types/:time_entry_type_id',
  headers: {
    'x-auth-token': '{{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}}/time_entry_types/:time_entry_type_id',
  headers: {'x-auth-token': '{{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}}/time_entry_types/:time_entry_type_id');

req.headers({
  'x-auth-token': '{{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}}/time_entry_types/:time_entry_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_types/:time_entry_type_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_types/:time_entry_type_id"]
                                                       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}}/time_entry_types/:time_entry_type_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_types/:time_entry_type_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/time_entry_types/:time_entry_type_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_types/:time_entry_type_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_types/:time_entry_type_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_types/:time_entry_type_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_types/:time_entry_type_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/time_entry_types/:time_entry_type_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_types/:time_entry_type_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_types/:time_entry_type_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_types/:time_entry_type_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/time_entry_types/:time_entry_type_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_types/:time_entry_type_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_types/:time_entry_type_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/time_entry_types/:time_entry_type_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_types/:time_entry_type_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_types/:time_entry_type_id")! 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 possible time entry unit types
{{baseUrl}}/time_entry_unit_types
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_unit_types");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/time_entry_unit_types" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_unit_types"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_unit_types"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_unit_types");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_unit_types"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/time_entry_unit_types HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/time_entry_unit_types")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_unit_types"))
    .header("x-auth-token", "{{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}}/time_entry_unit_types")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/time_entry_unit_types")
  .header("x-auth-token", "{{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}}/time_entry_unit_types');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/time_entry_unit_types',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_unit_types';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/time_entry_unit_types',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_unit_types")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_unit_types',
  headers: {
    'x-auth-token': '{{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}}/time_entry_unit_types',
  headers: {'x-auth-token': '{{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}}/time_entry_unit_types');

req.headers({
  'x-auth-token': '{{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}}/time_entry_unit_types',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_unit_types';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_unit_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}}/time_entry_unit_types" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_unit_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 => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/time_entry_unit_types', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_unit_types');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_unit_types');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_unit_types' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_unit_types' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/time_entry_unit_types", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_unit_types"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_unit_types"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_unit_types")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/time_entry_unit_types') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_unit_types";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_unit_types \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/time_entry_unit_types \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_unit_types
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_unit_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()
GET View time entry unit type
{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

time_entry_unit_type_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_unit_types/:time_entry_unit_type_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/time_entry_unit_types/:time_entry_unit_type_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id"))
    .header("x-auth-token", "{{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}}/time_entry_unit_types/:time_entry_unit_type_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id")
  .header("x-auth-token", "{{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}}/time_entry_unit_types/:time_entry_unit_type_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/time_entry_unit_types/:time_entry_unit_type_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_unit_types/:time_entry_unit_type_id',
  headers: {
    'x-auth-token': '{{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}}/time_entry_unit_types/:time_entry_unit_type_id',
  headers: {'x-auth-token': '{{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}}/time_entry_unit_types/:time_entry_unit_type_id');

req.headers({
  'x-auth-token': '{{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}}/time_entry_unit_types/:time_entry_unit_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id"]
                                                       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}}/time_entry_unit_types/:time_entry_unit_type_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/time_entry_unit_types/:time_entry_unit_type_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/time_entry_unit_types/:time_entry_unit_type_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_unit_types/:time_entry_unit_type_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_unit_types/:time_entry_unit_type_id")! 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 possible time entry value types
{{baseUrl}}/time_entry_value_types
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_value_types");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/time_entry_value_types" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_value_types"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_value_types"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_value_types");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_value_types"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/time_entry_value_types HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/time_entry_value_types")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_value_types"))
    .header("x-auth-token", "{{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}}/time_entry_value_types")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/time_entry_value_types")
  .header("x-auth-token", "{{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}}/time_entry_value_types');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/time_entry_value_types',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_value_types';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/time_entry_value_types',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_value_types")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_value_types',
  headers: {
    'x-auth-token': '{{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}}/time_entry_value_types',
  headers: {'x-auth-token': '{{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}}/time_entry_value_types');

req.headers({
  'x-auth-token': '{{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}}/time_entry_value_types',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_value_types';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_value_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}}/time_entry_value_types" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_value_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 => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/time_entry_value_types', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_value_types');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_value_types');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_value_types' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_value_types' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/time_entry_value_types", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_value_types"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_value_types"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_value_types")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/time_entry_value_types') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_value_types";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_value_types \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/time_entry_value_types \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_value_types
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_value_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()
GET View time entry value type
{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

time_entry_value_type_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/time_entry_value_types/:time_entry_value_type_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/time_entry_value_types/:time_entry_value_type_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id"))
    .header("x-auth-token", "{{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}}/time_entry_value_types/:time_entry_value_type_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id")
  .header("x-auth-token", "{{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}}/time_entry_value_types/:time_entry_value_type_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/time_entry_value_types/:time_entry_value_type_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/time_entry_value_types/:time_entry_value_type_id',
  headers: {
    'x-auth-token': '{{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}}/time_entry_value_types/:time_entry_value_type_id',
  headers: {'x-auth-token': '{{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}}/time_entry_value_types/:time_entry_value_type_id');

req.headers({
  'x-auth-token': '{{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}}/time_entry_value_types/:time_entry_value_type_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id"]
                                                       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}}/time_entry_value_types/:time_entry_value_type_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/time_entry_value_types/:time_entry_value_type_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/time_entry_value_types/:time_entry_value_type_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/time_entry_value_types/:time_entry_value_type_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/time_entry_value_types/:time_entry_value_type_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/time_entry_value_types/:time_entry_value_type_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/time_entry_value_types/:time_entry_value_type_id")! 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 Details of 1 user custom field attribute
{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_custom_field_attribute_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/user_custom_field_attributes/:user_custom_field_attribute_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user_custom_field_attributes/:user_custom_field_attribute_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id"))
    .header("x-auth-token", "{{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}}/user_custom_field_attributes/:user_custom_field_attribute_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id")
  .header("x-auth-token", "{{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}}/user_custom_field_attributes/:user_custom_field_attribute_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/user_custom_field_attributes/:user_custom_field_attribute_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user_custom_field_attributes/:user_custom_field_attribute_id',
  headers: {
    'x-auth-token': '{{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}}/user_custom_field_attributes/:user_custom_field_attribute_id',
  headers: {'x-auth-token': '{{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}}/user_custom_field_attributes/:user_custom_field_attribute_id');

req.headers({
  'x-auth-token': '{{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}}/user_custom_field_attributes/:user_custom_field_attribute_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id"]
                                                       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}}/user_custom_field_attributes/:user_custom_field_attribute_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/user_custom_field_attributes/:user_custom_field_attribute_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user_custom_field_attributes/:user_custom_field_attribute_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/user_custom_field_attributes/:user_custom_field_attribute_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user_custom_field_attributes/:user_custom_field_attribute_id")! 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 a list of user custom field attributes
{{baseUrl}}/user_custom_field_attributes
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user_custom_field_attributes");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user_custom_field_attributes" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/user_custom_field_attributes"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/user_custom_field_attributes"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user_custom_field_attributes");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user_custom_field_attributes"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user_custom_field_attributes HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user_custom_field_attributes")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user_custom_field_attributes"))
    .header("x-auth-token", "{{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}}/user_custom_field_attributes")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user_custom_field_attributes")
  .header("x-auth-token", "{{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}}/user_custom_field_attributes');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user_custom_field_attributes',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user_custom_field_attributes';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/user_custom_field_attributes',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user_custom_field_attributes")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user_custom_field_attributes',
  headers: {
    'x-auth-token': '{{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}}/user_custom_field_attributes',
  headers: {'x-auth-token': '{{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}}/user_custom_field_attributes');

req.headers({
  'x-auth-token': '{{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}}/user_custom_field_attributes',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user_custom_field_attributes';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user_custom_field_attributes"]
                                                       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}}/user_custom_field_attributes" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user_custom_field_attributes",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user_custom_field_attributes', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user_custom_field_attributes');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user_custom_field_attributes');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user_custom_field_attributes' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user_custom_field_attributes' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/user_custom_field_attributes", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user_custom_field_attributes"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user_custom_field_attributes"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user_custom_field_attributes")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user_custom_field_attributes') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user_custom_field_attributes";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/user_custom_field_attributes \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/user_custom_field_attributes \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/user_custom_field_attributes
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user_custom_field_attributes")! 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 a list of user custom field values
{{baseUrl}}/users/:user_id/user_custom_field_value
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/:user_id/user_custom_field_value");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/users/:user_id/user_custom_field_value" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/users/:user_id/user_custom_field_value"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/users/:user_id/user_custom_field_value"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/users/:user_id/user_custom_field_value");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users/:user_id/user_custom_field_value"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/users/:user_id/user_custom_field_value HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/users/:user_id/user_custom_field_value")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users/:user_id/user_custom_field_value"))
    .header("x-auth-token", "{{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}}/users/:user_id/user_custom_field_value")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/users/:user_id/user_custom_field_value")
  .header("x-auth-token", "{{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}}/users/:user_id/user_custom_field_value');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/users/:user_id/user_custom_field_value',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users/:user_id/user_custom_field_value';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/users/:user_id/user_custom_field_value',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/users/:user_id/user_custom_field_value")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/users/:user_id/user_custom_field_value',
  headers: {
    'x-auth-token': '{{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}}/users/:user_id/user_custom_field_value',
  headers: {'x-auth-token': '{{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}}/users/:user_id/user_custom_field_value');

req.headers({
  'x-auth-token': '{{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}}/users/:user_id/user_custom_field_value',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users/:user_id/user_custom_field_value';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users/:user_id/user_custom_field_value"]
                                                       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}}/users/:user_id/user_custom_field_value" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users/:user_id/user_custom_field_value",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/users/:user_id/user_custom_field_value', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/:user_id/user_custom_field_value');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/users/:user_id/user_custom_field_value');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/:user_id/user_custom_field_value' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/:user_id/user_custom_field_value' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/users/:user_id/user_custom_field_value", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/:user_id/user_custom_field_value"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/:user_id/user_custom_field_value"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/:user_id/user_custom_field_value")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/users/:user_id/user_custom_field_value') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users/:user_id/user_custom_field_value";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/:user_id/user_custom_field_value \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/users/:user_id/user_custom_field_value \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/users/:user_id/user_custom_field_value
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users/:user_id/user_custom_field_value")! 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 a single record of user custom field value
{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
user_custom_field_value_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/users/:user_id/user_custom_field_value/:user_custom_field_value_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id"))
    .header("x-auth-token", "{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id")
  .header("x-auth-token", "{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/users/:user_id/user_custom_field_value/:user_custom_field_value_id',
  headers: {
    'x-auth-token': '{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id',
  headers: {'x-auth-token': '{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id');

req.headers({
  'x-auth-token': '{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id"]
                                                       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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/users/:user_id/user_custom_field_value/:user_custom_field_value_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/users/:user_id/user_custom_field_value/:user_custom_field_value_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id")! 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 Update a single record of user custom field value
{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
user_custom_field_value_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/users/:user_id/user_custom_field_value/:user_custom_field_value_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id"))
    .header("x-auth-token", "{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id")
  .header("x-auth-token", "{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/users/:user_id/user_custom_field_value/:user_custom_field_value_id',
  headers: {
    'x-auth-token': '{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id',
  headers: {'x-auth-token': '{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id');

req.headers({
  'x-auth-token': '{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id"]
                                                       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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/users/:user_id/user_custom_field_value/:user_custom_field_value_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/users/:user_id/user_custom_field_value/:user_custom_field_value_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users/:user_id/user_custom_field_value/:user_custom_field_value_id")! 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()
POST Activate multiple users
{{baseUrl}}/users/bulkActivate
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/bulkActivate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/users/bulkActivate" {:headers {:x-auth-token "{{apiKey}}"}
                                                               :content-type :json
                                                               :form-params {:id []}})
require "http/client"

url = "{{baseUrl}}/users/bulkActivate"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": []\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}}/users/bulkActivate"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id\": []\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}}/users/bulkActivate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users/bulkActivate"

	payload := strings.NewReader("{\n  \"id\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/users/bulkActivate HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/users/bulkActivate")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users/bulkActivate"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"id\": []\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\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/users/bulkActivate")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/users/bulkActivate")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/users/bulkActivate');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/users/bulkActivate',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users/bulkActivate';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/users/bulkActivate',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/users/bulkActivate")
  .post(body)
  .addHeader("x-auth-token", "{{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/users/bulkActivate',
  headers: {
    'x-auth-token': '{{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: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/users/bulkActivate',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {id: []},
  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}}/users/bulkActivate');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: []
});

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}}/users/bulkActivate',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users/bulkActivate';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users/bulkActivate"]
                                                       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}}/users/bulkActivate" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users/bulkActivate",
  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' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/users/bulkActivate', [
  'body' => '{
  "id": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/bulkActivate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/users/bulkActivate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/bulkActivate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/bulkActivate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": []\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/users/bulkActivate", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/bulkActivate"

payload = { "id": [] }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/bulkActivate"

payload <- "{\n  \"id\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/bulkActivate")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/users/bulkActivate') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"id\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users/bulkActivate";

    let payload = json!({"id": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/bulkActivate \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http POST {{baseUrl}}/users/bulkActivate \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/users/bulkActivate
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users/bulkActivate")! 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 a user integration setting
{{baseUrl}}/users/:user_id/integration_settings
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
BODY json

{
  "integration_setting_id": "",
  "value": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/:user_id/integration_settings");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/users/:user_id/integration_settings" {:headers {:x-auth-token "{{apiKey}}"}
                                                                                :content-type :json
                                                                                :form-params {:integration_setting_id ""
                                                                                              :value ""}})
require "http/client"

url = "{{baseUrl}}/users/:user_id/integration_settings"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\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}}/users/:user_id/integration_settings"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\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}}/users/:user_id/integration_settings");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users/:user_id/integration_settings"

	payload := strings.NewReader("{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/users/:user_id/integration_settings HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 49

{
  "integration_setting_id": "",
  "value": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/users/:user_id/integration_settings")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users/:user_id/integration_settings"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\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  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/users/:user_id/integration_settings")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/users/:user_id/integration_settings")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  integration_setting_id: '',
  value: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/users/:user_id/integration_settings');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/users/:user_id/integration_settings',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {integration_setting_id: '', value: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users/:user_id/integration_settings';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"integration_setting_id":"","value":""}'
};

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}}/users/:user_id/integration_settings',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "integration_setting_id": "",\n  "value": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/users/:user_id/integration_settings")
  .post(body)
  .addHeader("x-auth-token", "{{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/users/:user_id/integration_settings',
  headers: {
    'x-auth-token': '{{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({integration_setting_id: '', value: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/users/:user_id/integration_settings',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {integration_setting_id: '', value: ''},
  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}}/users/:user_id/integration_settings');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  integration_setting_id: '',
  value: ''
});

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}}/users/:user_id/integration_settings',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {integration_setting_id: '', value: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users/:user_id/integration_settings';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"integration_setting_id":"","value":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"integration_setting_id": @"",
                              @"value": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users/:user_id/integration_settings"]
                                                       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}}/users/:user_id/integration_settings" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users/:user_id/integration_settings",
  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([
    'integration_setting_id' => '',
    'value' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/users/:user_id/integration_settings', [
  'body' => '{
  "integration_setting_id": "",
  "value": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/:user_id/integration_settings');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'integration_setting_id' => '',
  'value' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'integration_setting_id' => '',
  'value' => ''
]));
$request->setRequestUrl('{{baseUrl}}/users/:user_id/integration_settings');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/:user_id/integration_settings' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "integration_setting_id": "",
  "value": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/:user_id/integration_settings' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "integration_setting_id": "",
  "value": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/users/:user_id/integration_settings", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/:user_id/integration_settings"

payload = {
    "integration_setting_id": "",
    "value": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/:user_id/integration_settings"

payload <- "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/:user_id/integration_settings")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\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/users/:user_id/integration_settings') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"integration_setting_id\": \"\",\n  \"value\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users/:user_id/integration_settings";

    let payload = json!({
        "integration_setting_id": "",
        "value": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/:user_id/integration_settings \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "integration_setting_id": "",
  "value": ""
}'
echo '{
  "integration_setting_id": "",
  "value": ""
}' |  \
  http POST {{baseUrl}}/users/:user_id/integration_settings \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "integration_setting_id": "",\n  "value": ""\n}' \
  --output-document \
  - {{baseUrl}}/users/:user_id/integration_settings
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "integration_setting_id": "",
  "value": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users/:user_id/integration_settings")! 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 user to company
{{baseUrl}}/users
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "city_id": "",
  "cost_price": "",
  "email": "",
  "expected_billable_hours": "",
  "extra_price": "",
  "first_name": "",
  "hide_address": false,
  "hide_phone": false,
  "initials": "",
  "is_active": false,
  "language_id": "",
  "last_name": "",
  "mobile": "",
  "mobile_countrycode": "",
  "password": "",
  "phone": "",
  "phone_countrycode": "",
  "receive_form_mails": false,
  "roles": {
    "_ids": []
  },
  "sale_price": "",
  "street_name": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_name\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/users" {:headers {:x-auth-token "{{apiKey}}"}
                                                  :content-type :json
                                                  :form-params {:city_id ""
                                                                :cost_price ""
                                                                :email ""
                                                                :expected_billable_hours ""
                                                                :extra_price ""
                                                                :first_name ""
                                                                :hide_address false
                                                                :hide_phone false
                                                                :initials ""
                                                                :is_active false
                                                                :language_id ""
                                                                :last_name ""
                                                                :mobile ""
                                                                :mobile_countrycode ""
                                                                :password ""
                                                                :phone ""
                                                                :phone_countrycode ""
                                                                :receive_form_mails false
                                                                :roles {:_ids []}
                                                                :sale_price ""
                                                                :street_name ""}})
require "http/client"

url = "{{baseUrl}}/users"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"city_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_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}}/users"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"city_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_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}}/users");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"city_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_name\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users"

	payload := strings.NewReader("{\n  \"city_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_name\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/users HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 465

{
  "city_id": "",
  "cost_price": "",
  "email": "",
  "expected_billable_hours": "",
  "extra_price": "",
  "first_name": "",
  "hide_address": false,
  "hide_phone": false,
  "initials": "",
  "is_active": false,
  "language_id": "",
  "last_name": "",
  "mobile": "",
  "mobile_countrycode": "",
  "password": "",
  "phone": "",
  "phone_countrycode": "",
  "receive_form_mails": false,
  "roles": {
    "_ids": []
  },
  "sale_price": "",
  "street_name": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/users")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"city_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_name\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"city_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_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  \"city_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_name\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/users")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/users")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"city_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_name\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  city_id: '',
  cost_price: '',
  email: '',
  expected_billable_hours: '',
  extra_price: '',
  first_name: '',
  hide_address: false,
  hide_phone: false,
  initials: '',
  is_active: false,
  language_id: '',
  last_name: '',
  mobile: '',
  mobile_countrycode: '',
  password: '',
  phone: '',
  phone_countrycode: '',
  receive_form_mails: false,
  roles: {
    _ids: []
  },
  sale_price: '',
  street_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}}/users');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/users',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    city_id: '',
    cost_price: '',
    email: '',
    expected_billable_hours: '',
    extra_price: '',
    first_name: '',
    hide_address: false,
    hide_phone: false,
    initials: '',
    is_active: false,
    language_id: '',
    last_name: '',
    mobile: '',
    mobile_countrycode: '',
    password: '',
    phone: '',
    phone_countrycode: '',
    receive_form_mails: false,
    roles: {_ids: []},
    sale_price: '',
    street_name: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"city_id":"","cost_price":"","email":"","expected_billable_hours":"","extra_price":"","first_name":"","hide_address":false,"hide_phone":false,"initials":"","is_active":false,"language_id":"","last_name":"","mobile":"","mobile_countrycode":"","password":"","phone":"","phone_countrycode":"","receive_form_mails":false,"roles":{"_ids":[]},"sale_price":"","street_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}}/users',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "city_id": "",\n  "cost_price": "",\n  "email": "",\n  "expected_billable_hours": "",\n  "extra_price": "",\n  "first_name": "",\n  "hide_address": false,\n  "hide_phone": false,\n  "initials": "",\n  "is_active": false,\n  "language_id": "",\n  "last_name": "",\n  "mobile": "",\n  "mobile_countrycode": "",\n  "password": "",\n  "phone": "",\n  "phone_countrycode": "",\n  "receive_form_mails": false,\n  "roles": {\n    "_ids": []\n  },\n  "sale_price": "",\n  "street_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  \"city_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_name\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/users")
  .post(body)
  .addHeader("x-auth-token", "{{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/users',
  headers: {
    'x-auth-token': '{{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_id: '',
  cost_price: '',
  email: '',
  expected_billable_hours: '',
  extra_price: '',
  first_name: '',
  hide_address: false,
  hide_phone: false,
  initials: '',
  is_active: false,
  language_id: '',
  last_name: '',
  mobile: '',
  mobile_countrycode: '',
  password: '',
  phone: '',
  phone_countrycode: '',
  receive_form_mails: false,
  roles: {_ids: []},
  sale_price: '',
  street_name: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/users',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {
    city_id: '',
    cost_price: '',
    email: '',
    expected_billable_hours: '',
    extra_price: '',
    first_name: '',
    hide_address: false,
    hide_phone: false,
    initials: '',
    is_active: false,
    language_id: '',
    last_name: '',
    mobile: '',
    mobile_countrycode: '',
    password: '',
    phone: '',
    phone_countrycode: '',
    receive_form_mails: false,
    roles: {_ids: []},
    sale_price: '',
    street_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}}/users');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  city_id: '',
  cost_price: '',
  email: '',
  expected_billable_hours: '',
  extra_price: '',
  first_name: '',
  hide_address: false,
  hide_phone: false,
  initials: '',
  is_active: false,
  language_id: '',
  last_name: '',
  mobile: '',
  mobile_countrycode: '',
  password: '',
  phone: '',
  phone_countrycode: '',
  receive_form_mails: false,
  roles: {
    _ids: []
  },
  sale_price: '',
  street_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}}/users',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {
    city_id: '',
    cost_price: '',
    email: '',
    expected_billable_hours: '',
    extra_price: '',
    first_name: '',
    hide_address: false,
    hide_phone: false,
    initials: '',
    is_active: false,
    language_id: '',
    last_name: '',
    mobile: '',
    mobile_countrycode: '',
    password: '',
    phone: '',
    phone_countrycode: '',
    receive_form_mails: false,
    roles: {_ids: []},
    sale_price: '',
    street_name: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"city_id":"","cost_price":"","email":"","expected_billable_hours":"","extra_price":"","first_name":"","hide_address":false,"hide_phone":false,"initials":"","is_active":false,"language_id":"","last_name":"","mobile":"","mobile_countrycode":"","password":"","phone":"","phone_countrycode":"","receive_form_mails":false,"roles":{"_ids":[]},"sale_price":"","street_name":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"city_id": @"",
                              @"cost_price": @"",
                              @"email": @"",
                              @"expected_billable_hours": @"",
                              @"extra_price": @"",
                              @"first_name": @"",
                              @"hide_address": @NO,
                              @"hide_phone": @NO,
                              @"initials": @"",
                              @"is_active": @NO,
                              @"language_id": @"",
                              @"last_name": @"",
                              @"mobile": @"",
                              @"mobile_countrycode": @"",
                              @"password": @"",
                              @"phone": @"",
                              @"phone_countrycode": @"",
                              @"receive_form_mails": @NO,
                              @"roles": @{ @"_ids": @[  ] },
                              @"sale_price": @"",
                              @"street_name": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users"]
                                                       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}}/users" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"city_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_name\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users",
  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([
    'city_id' => '',
    'cost_price' => '',
    'email' => '',
    'expected_billable_hours' => '',
    'extra_price' => '',
    'first_name' => '',
    'hide_address' => null,
    'hide_phone' => null,
    'initials' => '',
    'is_active' => null,
    'language_id' => '',
    'last_name' => '',
    'mobile' => '',
    'mobile_countrycode' => '',
    'password' => '',
    'phone' => '',
    'phone_countrycode' => '',
    'receive_form_mails' => null,
    'roles' => [
        '_ids' => [
                
        ]
    ],
    'sale_price' => '',
    'street_name' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/users', [
  'body' => '{
  "city_id": "",
  "cost_price": "",
  "email": "",
  "expected_billable_hours": "",
  "extra_price": "",
  "first_name": "",
  "hide_address": false,
  "hide_phone": false,
  "initials": "",
  "is_active": false,
  "language_id": "",
  "last_name": "",
  "mobile": "",
  "mobile_countrycode": "",
  "password": "",
  "phone": "",
  "phone_countrycode": "",
  "receive_form_mails": false,
  "roles": {
    "_ids": []
  },
  "sale_price": "",
  "street_name": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'city_id' => '',
  'cost_price' => '',
  'email' => '',
  'expected_billable_hours' => '',
  'extra_price' => '',
  'first_name' => '',
  'hide_address' => null,
  'hide_phone' => null,
  'initials' => '',
  'is_active' => null,
  'language_id' => '',
  'last_name' => '',
  'mobile' => '',
  'mobile_countrycode' => '',
  'password' => '',
  'phone' => '',
  'phone_countrycode' => '',
  'receive_form_mails' => null,
  'roles' => [
    '_ids' => [
        
    ]
  ],
  'sale_price' => '',
  'street_name' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'city_id' => '',
  'cost_price' => '',
  'email' => '',
  'expected_billable_hours' => '',
  'extra_price' => '',
  'first_name' => '',
  'hide_address' => null,
  'hide_phone' => null,
  'initials' => '',
  'is_active' => null,
  'language_id' => '',
  'last_name' => '',
  'mobile' => '',
  'mobile_countrycode' => '',
  'password' => '',
  'phone' => '',
  'phone_countrycode' => '',
  'receive_form_mails' => null,
  'roles' => [
    '_ids' => [
        
    ]
  ],
  'sale_price' => '',
  'street_name' => ''
]));
$request->setRequestUrl('{{baseUrl}}/users');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "city_id": "",
  "cost_price": "",
  "email": "",
  "expected_billable_hours": "",
  "extra_price": "",
  "first_name": "",
  "hide_address": false,
  "hide_phone": false,
  "initials": "",
  "is_active": false,
  "language_id": "",
  "last_name": "",
  "mobile": "",
  "mobile_countrycode": "",
  "password": "",
  "phone": "",
  "phone_countrycode": "",
  "receive_form_mails": false,
  "roles": {
    "_ids": []
  },
  "sale_price": "",
  "street_name": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "city_id": "",
  "cost_price": "",
  "email": "",
  "expected_billable_hours": "",
  "extra_price": "",
  "first_name": "",
  "hide_address": false,
  "hide_phone": false,
  "initials": "",
  "is_active": false,
  "language_id": "",
  "last_name": "",
  "mobile": "",
  "mobile_countrycode": "",
  "password": "",
  "phone": "",
  "phone_countrycode": "",
  "receive_form_mails": false,
  "roles": {
    "_ids": []
  },
  "sale_price": "",
  "street_name": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"city_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_name\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/users", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users"

payload = {
    "city_id": "",
    "cost_price": "",
    "email": "",
    "expected_billable_hours": "",
    "extra_price": "",
    "first_name": "",
    "hide_address": False,
    "hide_phone": False,
    "initials": "",
    "is_active": False,
    "language_id": "",
    "last_name": "",
    "mobile": "",
    "mobile_countrycode": "",
    "password": "",
    "phone": "",
    "phone_countrycode": "",
    "receive_form_mails": False,
    "roles": { "_ids": [] },
    "sale_price": "",
    "street_name": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users"

payload <- "{\n  \"city_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_name\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"city_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_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/users') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"city_id\": \"\",\n  \"cost_price\": \"\",\n  \"email\": \"\",\n  \"expected_billable_hours\": \"\",\n  \"extra_price\": \"\",\n  \"first_name\": \"\",\n  \"hide_address\": false,\n  \"hide_phone\": false,\n  \"initials\": \"\",\n  \"is_active\": false,\n  \"language_id\": \"\",\n  \"last_name\": \"\",\n  \"mobile\": \"\",\n  \"mobile_countrycode\": \"\",\n  \"password\": \"\",\n  \"phone\": \"\",\n  \"phone_countrycode\": \"\",\n  \"receive_form_mails\": false,\n  \"roles\": {\n    \"_ids\": []\n  },\n  \"sale_price\": \"\",\n  \"street_name\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users";

    let payload = json!({
        "city_id": "",
        "cost_price": "",
        "email": "",
        "expected_billable_hours": "",
        "extra_price": "",
        "first_name": "",
        "hide_address": false,
        "hide_phone": false,
        "initials": "",
        "is_active": false,
        "language_id": "",
        "last_name": "",
        "mobile": "",
        "mobile_countrycode": "",
        "password": "",
        "phone": "",
        "phone_countrycode": "",
        "receive_form_mails": false,
        "roles": json!({"_ids": ()}),
        "sale_price": "",
        "street_name": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "city_id": "",
  "cost_price": "",
  "email": "",
  "expected_billable_hours": "",
  "extra_price": "",
  "first_name": "",
  "hide_address": false,
  "hide_phone": false,
  "initials": "",
  "is_active": false,
  "language_id": "",
  "last_name": "",
  "mobile": "",
  "mobile_countrycode": "",
  "password": "",
  "phone": "",
  "phone_countrycode": "",
  "receive_form_mails": false,
  "roles": {
    "_ids": []
  },
  "sale_price": "",
  "street_name": ""
}'
echo '{
  "city_id": "",
  "cost_price": "",
  "email": "",
  "expected_billable_hours": "",
  "extra_price": "",
  "first_name": "",
  "hide_address": false,
  "hide_phone": false,
  "initials": "",
  "is_active": false,
  "language_id": "",
  "last_name": "",
  "mobile": "",
  "mobile_countrycode": "",
  "password": "",
  "phone": "",
  "phone_countrycode": "",
  "receive_form_mails": false,
  "roles": {
    "_ids": []
  },
  "sale_price": "",
  "street_name": ""
}' |  \
  http POST {{baseUrl}}/users \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "city_id": "",\n  "cost_price": "",\n  "email": "",\n  "expected_billable_hours": "",\n  "extra_price": "",\n  "first_name": "",\n  "hide_address": false,\n  "hide_phone": false,\n  "initials": "",\n  "is_active": false,\n  "language_id": "",\n  "last_name": "",\n  "mobile": "",\n  "mobile_countrycode": "",\n  "password": "",\n  "phone": "",\n  "phone_countrycode": "",\n  "receive_form_mails": false,\n  "roles": {\n    "_ids": []\n  },\n  "sale_price": "",\n  "street_name": ""\n}' \
  --output-document \
  - {{baseUrl}}/users
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "city_id": "",
  "cost_price": "",
  "email": "",
  "expected_billable_hours": "",
  "extra_price": "",
  "first_name": "",
  "hide_address": false,
  "hide_phone": false,
  "initials": "",
  "is_active": false,
  "language_id": "",
  "last_name": "",
  "mobile": "",
  "mobile_countrycode": "",
  "password": "",
  "phone": "",
  "phone_countrycode": "",
  "receive_form_mails": false,
  "roles": ["_ids": []],
  "sale_price": "",
  "street_name": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users")! 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 Deactivate multiple users
{{baseUrl}}/users/bulkDeactivate
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "id": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/bulkDeactivate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/users/bulkDeactivate" {:headers {:x-auth-token "{{apiKey}}"}
                                                                 :content-type :json
                                                                 :form-params {:id []}})
require "http/client"

url = "{{baseUrl}}/users/bulkDeactivate"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": []\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}}/users/bulkDeactivate"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"id\": []\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}}/users/bulkDeactivate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users/bulkDeactivate"

	payload := strings.NewReader("{\n  \"id\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/users/bulkDeactivate HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/users/bulkDeactivate")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users/bulkDeactivate"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"id\": []\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\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/users/bulkDeactivate")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/users/bulkDeactivate")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"id\": []\n}")
  .asString();
const data = JSON.stringify({
  id: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/users/bulkDeactivate');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/users/bulkDeactivate',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users/bulkDeactivate';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

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}}/users/bulkDeactivate',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": []\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\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/users/bulkDeactivate")
  .post(body)
  .addHeader("x-auth-token", "{{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/users/bulkDeactivate',
  headers: {
    'x-auth-token': '{{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: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/users/bulkDeactivate',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {id: []},
  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}}/users/bulkDeactivate');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: []
});

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}}/users/bulkDeactivate',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {id: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users/bulkDeactivate';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"id":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"id": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users/bulkDeactivate"]
                                                       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}}/users/bulkDeactivate" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users/bulkDeactivate",
  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' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/users/bulkDeactivate', [
  'body' => '{
  "id": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/bulkDeactivate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/users/bulkDeactivate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/bulkDeactivate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/bulkDeactivate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": []\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/users/bulkDeactivate", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/bulkDeactivate"

payload = { "id": [] }
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/bulkDeactivate"

payload <- "{\n  \"id\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/bulkDeactivate")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": []\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/users/bulkDeactivate') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"id\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users/bulkDeactivate";

    let payload = json!({"id": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/bulkDeactivate \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "id": []
}'
echo '{
  "id": []
}' |  \
  http POST {{baseUrl}}/users/bulkDeactivate \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": []\n}' \
  --output-document \
  - {{baseUrl}}/users/bulkDeactivate
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = ["id": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users/bulkDeactivate")! 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 Delete a user integration setting
{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
integration_settings_user_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/users/:user_id/integration_settings/:integration_settings_user_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/users/:user_id/integration_settings/:integration_settings_user_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"))
    .header("x-auth-token", "{{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}}/users/:user_id/integration_settings/:integration_settings_user_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")
  .header("x-auth-token", "{{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}}/users/:user_id/integration_settings/:integration_settings_user_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/users/:user_id/integration_settings/:integration_settings_user_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/users/:user_id/integration_settings/:integration_settings_user_id',
  headers: {
    'x-auth-token': '{{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}}/users/:user_id/integration_settings/:integration_settings_user_id',
  headers: {'x-auth-token': '{{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}}/users/:user_id/integration_settings/:integration_settings_user_id');

req.headers({
  'x-auth-token': '{{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}}/users/:user_id/integration_settings/:integration_settings_user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"]
                                                       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}}/users/:user_id/integration_settings/:integration_settings_user_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/users/:user_id/integration_settings/:integration_settings_user_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/users/:user_id/integration_settings/:integration_settings_user_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/:user_id/integration_settings/:integration_settings_user_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")! 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 user
{{baseUrl}}/users/:user_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/:user_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/users/:user_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/users/:user_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/users/:user_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/users/:user_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users/:user_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/users/:user_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/users/:user_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users/:user_id"))
    .header("x-auth-token", "{{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}}/users/:user_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/users/:user_id")
  .header("x-auth-token", "{{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}}/users/:user_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/users/:user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users/:user_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/users/:user_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/users/:user_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/users/:user_id',
  headers: {
    'x-auth-token': '{{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}}/users/:user_id',
  headers: {'x-auth-token': '{{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}}/users/:user_id');

req.headers({
  'x-auth-token': '{{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}}/users/:user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users/:user_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users/:user_id"]
                                                       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}}/users/:user_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users/:user_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/users/:user_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/:user_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/users/:user_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/:user_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/:user_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/users/:user_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/:user_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/:user_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/:user_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/users/:user_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users/:user_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/:user_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/users/:user_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/users/:user_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users/:user_id")! 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()
PUT Edit a user integration setting
{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
integration_settings_user_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/users/:user_id/integration_settings/:integration_settings_user_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/users/:user_id/integration_settings/:integration_settings_user_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"))
    .header("x-auth-token", "{{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}}/users/:user_id/integration_settings/:integration_settings_user_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")
  .header("x-auth-token", "{{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}}/users/:user_id/integration_settings/:integration_settings_user_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/users/:user_id/integration_settings/:integration_settings_user_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/users/:user_id/integration_settings/:integration_settings_user_id',
  headers: {
    'x-auth-token': '{{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}}/users/:user_id/integration_settings/:integration_settings_user_id',
  headers: {'x-auth-token': '{{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}}/users/:user_id/integration_settings/:integration_settings_user_id');

req.headers({
  'x-auth-token': '{{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}}/users/:user_id/integration_settings/:integration_settings_user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"]
                                                       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}}/users/:user_id/integration_settings/:integration_settings_user_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/users/:user_id/integration_settings/:integration_settings_user_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/users/:user_id/integration_settings/:integration_settings_user_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/:user_id/integration_settings/:integration_settings_user_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")! 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 Edit user
{{baseUrl}}/users/:user_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/:user_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/users/:user_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/users/:user_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/users/:user_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/users/:user_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users/:user_id"

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/users/:user_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/users/:user_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users/:user_id"))
    .header("x-auth-token", "{{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}}/users/:user_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/users/:user_id")
  .header("x-auth-token", "{{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}}/users/:user_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/users/:user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users/:user_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{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}}/users/:user_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/users/:user_id")
  .put(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/users/:user_id',
  headers: {
    'x-auth-token': '{{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}}/users/:user_id',
  headers: {'x-auth-token': '{{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}}/users/:user_id');

req.headers({
  'x-auth-token': '{{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}}/users/:user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users/:user_id';
const options = {method: 'PUT', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users/:user_id"]
                                                       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}}/users/:user_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users/:user_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/users/:user_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/:user_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/users/:user_id');
$request->setRequestMethod('PUT');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/:user_id' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/:user_id' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/users/:user_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/:user_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.put(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/:user_id"

response <- VERB("PUT", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/:user_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/users/:user_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users/:user_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/:user_id \
  --header 'x-auth-token: {{apiKey}}'
http PUT {{baseUrl}}/users/:user_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/users/:user_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users/:user_id")! 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()
GET Get a list of user integration settings
{{baseUrl}}/users/:user_id/integration_settings
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/:user_id/integration_settings");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/users/:user_id/integration_settings" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/users/:user_id/integration_settings"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/users/:user_id/integration_settings"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/users/:user_id/integration_settings");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users/:user_id/integration_settings"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/users/:user_id/integration_settings HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/users/:user_id/integration_settings")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users/:user_id/integration_settings"))
    .header("x-auth-token", "{{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}}/users/:user_id/integration_settings")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/users/:user_id/integration_settings")
  .header("x-auth-token", "{{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}}/users/:user_id/integration_settings');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/users/:user_id/integration_settings',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users/:user_id/integration_settings';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/users/:user_id/integration_settings',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/users/:user_id/integration_settings")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/users/:user_id/integration_settings',
  headers: {
    'x-auth-token': '{{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}}/users/:user_id/integration_settings',
  headers: {'x-auth-token': '{{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}}/users/:user_id/integration_settings');

req.headers({
  'x-auth-token': '{{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}}/users/:user_id/integration_settings',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users/:user_id/integration_settings';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users/:user_id/integration_settings"]
                                                       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}}/users/:user_id/integration_settings" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users/:user_id/integration_settings",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/users/:user_id/integration_settings', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/:user_id/integration_settings');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/users/:user_id/integration_settings');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/:user_id/integration_settings' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/:user_id/integration_settings' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/users/:user_id/integration_settings", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/:user_id/integration_settings"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/:user_id/integration_settings"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/:user_id/integration_settings")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/users/:user_id/integration_settings') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users/:user_id/integration_settings";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/:user_id/integration_settings \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/users/:user_id/integration_settings \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/users/:user_id/integration_settings
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users/:user_id/integration_settings")! 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 a user integration setting
{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
integration_settings_user_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/users/:user_id/integration_settings/:integration_settings_user_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/users/:user_id/integration_settings/:integration_settings_user_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"))
    .header("x-auth-token", "{{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}}/users/:user_id/integration_settings/:integration_settings_user_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")
  .header("x-auth-token", "{{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}}/users/:user_id/integration_settings/:integration_settings_user_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/users/:user_id/integration_settings/:integration_settings_user_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/users/:user_id/integration_settings/:integration_settings_user_id',
  headers: {
    'x-auth-token': '{{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}}/users/:user_id/integration_settings/:integration_settings_user_id',
  headers: {'x-auth-token': '{{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}}/users/:user_id/integration_settings/:integration_settings_user_id');

req.headers({
  'x-auth-token': '{{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}}/users/:user_id/integration_settings/:integration_settings_user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"]
                                                       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}}/users/:user_id/integration_settings/:integration_settings_user_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/users/:user_id/integration_settings/:integration_settings_user_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/users/:user_id/integration_settings/:integration_settings_user_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/:user_id/integration_settings/:integration_settings_user_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users/:user_id/integration_settings/:integration_settings_user_id")! 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 list of users in company
{{baseUrl}}/users
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/users" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/users"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/users"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/users");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/users HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/users")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users"))
    .header("x-auth-token", "{{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}}/users")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/users")
  .header("x-auth-token", "{{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}}/users');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/users',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/users',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/users")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/users',
  headers: {
    'x-auth-token': '{{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}}/users',
  headers: {'x-auth-token': '{{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}}/users');

req.headers({
  'x-auth-token': '{{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}}/users',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/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}}/users" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/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 => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/users', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/users');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/users", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/users') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/users \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/users
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/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()
GET Resend Welcome SMS to the user
{{baseUrl}}/users/resendWelcomeSms
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/resendWelcomeSms");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/users/resendWelcomeSms" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/users/resendWelcomeSms"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/users/resendWelcomeSms"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/users/resendWelcomeSms");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users/resendWelcomeSms"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/users/resendWelcomeSms HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/users/resendWelcomeSms")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users/resendWelcomeSms"))
    .header("x-auth-token", "{{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}}/users/resendWelcomeSms")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/users/resendWelcomeSms")
  .header("x-auth-token", "{{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}}/users/resendWelcomeSms');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/users/resendWelcomeSms',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users/resendWelcomeSms';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/users/resendWelcomeSms',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/users/resendWelcomeSms")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/users/resendWelcomeSms',
  headers: {
    'x-auth-token': '{{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}}/users/resendWelcomeSms',
  headers: {'x-auth-token': '{{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}}/users/resendWelcomeSms');

req.headers({
  'x-auth-token': '{{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}}/users/resendWelcomeSms',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users/resendWelcomeSms';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users/resendWelcomeSms"]
                                                       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}}/users/resendWelcomeSms" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users/resendWelcomeSms",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/users/resendWelcomeSms', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/resendWelcomeSms');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/users/resendWelcomeSms');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/resendWelcomeSms' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/resendWelcomeSms' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/users/resendWelcomeSms", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/resendWelcomeSms"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/resendWelcomeSms"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/resendWelcomeSms")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/users/resendWelcomeSms') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users/resendWelcomeSms";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/resendWelcomeSms \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/users/resendWelcomeSms \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/users/resendWelcomeSms
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users/resendWelcomeSms")! 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 Upload a new image to a user
{{baseUrl}}/users/:user_id/uploadImage
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
BODY multipartForm

Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/:user_id/uploadImage");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{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=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/users/:user_id/uploadImage" {:headers {:x-auth-token "{{apiKey}}"}
                                                                       :multipart [{:name "image"
                                                                                    :content ""}]})
require "http/client"

url = "{{baseUrl}}/users/:user_id/uploadImage"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "multipart/form-data; boundary=---011000010111000001101001"
}
reqBody = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/users/:user_id/uploadImage"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new MultipartFormDataContent
    {
        new StringContent("")
        {
            Headers =
            {
                ContentDisposition = new ContentDispositionHeaderValue("form-data")
                {
                    Name = "image",
                }
            }
        },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/users/:user_id/uploadImage");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001");
request.AddParameter("multipart/form-data; boundary=---011000010111000001101001", "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/users/:user_id/uploadImage"

	payload := strings.NewReader("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/users/:user_id/uploadImage HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: multipart/form-data; boundary=---011000010111000001101001
Host: example.com
Content-Length: 114

-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/users/:user_id/uploadImage")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .setBody("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/users/:user_id/uploadImage"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
    .method("POST", HttpRequest.BodyPublishers.ofString("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n");
Request request = new Request.Builder()
  .url("{{baseUrl}}/users/:user_id/uploadImage")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/users/:user_id/uploadImage")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "multipart/form-data; boundary=---011000010111000001101001")
  .body("-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
  .asString();
const data = new FormData();
data.append('image', '');

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/users/:user_id/uploadImage');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const form = new FormData();
form.append('image', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/users/:user_id/uploadImage',
  headers: {
    'x-auth-token': '{{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}}/users/:user_id/uploadImage';
const form = new FormData();
form.append('image', '');

const options = {method: 'POST', headers: {'x-auth-token': '{{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('image', '');

const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/users/:user_id/uploadImage',
  method: 'POST',
  headers: {
    'x-auth-token': '{{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=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n")
val request = Request.Builder()
  .url("{{baseUrl}}/users/:user_id/uploadImage")
  .post(body)
  .addHeader("x-auth-token", "{{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/users/:user_id/uploadImage',
  headers: {
    'x-auth-token': '{{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="image"\r\n\r\n\r\n-----011000010111000001101001--\r\n');
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/users/:user_id/uploadImage',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  formData: {image: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/users/:user_id/uploadImage');

req.headers({
  'x-auth-token': '{{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}}/users/:user_id/uploadImage',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'multipart/form-data; boundary=---011000010111000001101001'
  },
  data: '-----011000010111000001101001\r\nContent-Disposition: form-data; name="image"\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('image', '');

const url = '{{baseUrl}}/users/:user_id/uploadImage';
const options = {method: 'POST', headers: {'x-auth-token': '{{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 = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"multipart/form-data; boundary=---011000010111000001101001" };
NSArray *parameters = @[ @{ @"name": @"image", @"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}}/users/:user_id/uploadImage"]
                                                       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}}/users/:user_id/uploadImage" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "multipart/form-data; boundary=---011000010111000001101001");
] in
let body = Cohttp_lwt_body.of_string "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/users/:user_id/uploadImage",
  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=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n",
  CURLOPT_HTTPHEADER => [
    "content-type: multipart/form-data; boundary=---011000010111000001101001",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/users/:user_id/uploadImage', [
  'headers' => [
    'content-type' => 'multipart/form-data; boundary=---011000010111000001101001',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/:user_id/uploadImage');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'multipart/form-data; boundary=---011000010111000001101001'
]);

$request->setBody('-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
');

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
addForm(null, null);

$request->setRequestUrl('{{baseUrl}}/users/:user_id/uploadImage');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/:user_id/uploadImage' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "multipart/form-data; boundary=---011000010111000001101001")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/:user_id/uploadImage' -Method POST -Headers $headers -ContentType 'multipart/form-data; boundary=---011000010111000001101001' -Body '-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "multipart/form-data; boundary=---011000010111000001101001"
}

conn.request("POST", "/baseUrl/users/:user_id/uploadImage", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/:user_id/uploadImage"

payload = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "multipart/form-data; boundary=---011000010111000001101001"
}

response = requests.post(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/:user_id/uploadImage"

payload <- "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\r\n\r\n\r\n-----011000010111000001101001--\r\n"

encode <- "multipart"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("multipart/form-data"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/:user_id/uploadImage")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'multipart/form-data; boundary=---011000010111000001101001'
request.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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/users/:user_id/uploadImage') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "-----011000010111000001101001\r\nContent-Disposition: form-data; name=\"image\"\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}}/users/:user_id/uploadImage";

    let form = reqwest::multipart::Form::new()
        .text("image", "");
    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/:user_id/uploadImage \
  --header 'content-type: multipart/form-data' \
  --header 'x-auth-token: {{apiKey}}' \
  --form image=
echo '-----011000010111000001101001
Content-Disposition: form-data; name="image"


-----011000010111000001101001--
' |  \
  http POST {{baseUrl}}/users/:user_id/uploadImage \
  content-type:'multipart/form-data; boundary=---011000010111000001101001' \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: multipart/form-data; boundary=---011000010111000001101001' \
  --body-data '-----011000010111000001101001\r\nContent-Disposition: form-data; name="image"\r\n\r\n\r\n-----011000010111000001101001--\r\n' \
  --output-document \
  - {{baseUrl}}/users/:user_id/uploadImage
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "multipart/form-data; boundary=---011000010111000001101001"
]
let parameters = [
  [
    "name": "image",
    "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}}/users/:user_id/uploadImage")! 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 View user
{{baseUrl}}/users/:user_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

user_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/users/:user_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/users/:user_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/users/:user_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/users/:user_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/users/:user_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/users/:user_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/users/:user_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/users/:user_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/users/:user_id"))
    .header("x-auth-token", "{{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}}/users/:user_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/users/:user_id")
  .header("x-auth-token", "{{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}}/users/:user_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/users/:user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/users/:user_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/users/:user_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/users/:user_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/users/:user_id',
  headers: {
    'x-auth-token': '{{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}}/users/:user_id',
  headers: {'x-auth-token': '{{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}}/users/:user_id');

req.headers({
  'x-auth-token': '{{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}}/users/:user_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/users/:user_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/users/:user_id"]
                                                       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}}/users/:user_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/users/:user_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/users/:user_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/users/:user_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/users/:user_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/users/:user_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/users/:user_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/users/:user_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/users/:user_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/users/:user_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/users/:user_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/users/:user_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/users/:user_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/users/:user_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/users/:user_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/users/:user_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/users/:user_id")! 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 a list of price files
{{baseUrl}}/vendor_product_price_files
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/vendor_product_price_files");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/vendor_product_price_files" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/vendor_product_price_files"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/vendor_product_price_files"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/vendor_product_price_files");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/vendor_product_price_files"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/vendor_product_price_files HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/vendor_product_price_files")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/vendor_product_price_files"))
    .header("x-auth-token", "{{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}}/vendor_product_price_files")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/vendor_product_price_files")
  .header("x-auth-token", "{{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}}/vendor_product_price_files');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/vendor_product_price_files',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/vendor_product_price_files';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/vendor_product_price_files',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/vendor_product_price_files")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/vendor_product_price_files',
  headers: {
    'x-auth-token': '{{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}}/vendor_product_price_files',
  headers: {'x-auth-token': '{{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}}/vendor_product_price_files');

req.headers({
  'x-auth-token': '{{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}}/vendor_product_price_files',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/vendor_product_price_files';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/vendor_product_price_files"]
                                                       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}}/vendor_product_price_files" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/vendor_product_price_files",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/vendor_product_price_files', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/vendor_product_price_files');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/vendor_product_price_files');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/vendor_product_price_files' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/vendor_product_price_files' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/vendor_product_price_files", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/vendor_product_price_files"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/vendor_product_price_files"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/vendor_product_price_files")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/vendor_product_price_files') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/vendor_product_price_files";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/vendor_product_price_files \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/vendor_product_price_files \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/vendor_product_price_files
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/vendor_product_price_files")! 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 a single price file
{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

vendor_product_price_file_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/vendor_product_price_files/:vendor_product_price_file_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/vendor_product_price_files/:vendor_product_price_file_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id"))
    .header("x-auth-token", "{{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}}/vendor_product_price_files/:vendor_product_price_file_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id")
  .header("x-auth-token", "{{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}}/vendor_product_price_files/:vendor_product_price_file_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/vendor_product_price_files/:vendor_product_price_file_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/vendor_product_price_files/:vendor_product_price_file_id',
  headers: {
    'x-auth-token': '{{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}}/vendor_product_price_files/:vendor_product_price_file_id',
  headers: {'x-auth-token': '{{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}}/vendor_product_price_files/:vendor_product_price_file_id');

req.headers({
  'x-auth-token': '{{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}}/vendor_product_price_files/:vendor_product_price_file_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id"]
                                                       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}}/vendor_product_price_files/:vendor_product_price_file_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/vendor_product_price_files/:vendor_product_price_file_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/vendor_product_price_files/:vendor_product_price_file_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/vendor_product_price_files/:vendor_product_price_file_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/vendor_product_price_files/:vendor_product_price_file_id")! 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 Upload a vendor price file
{{baseUrl}}/vendor_product_price_files
HEADERS

X-Auth-Token
{{apiKey}}
BODY formUrlEncoded

companies_vendor_id
file
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/vendor_product_price_files");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/x-www-form-urlencoded");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "companies_vendor_id=&file=");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/vendor_product_price_files" {:headers {:x-auth-token "{{apiKey}}"}
                                                                       :form-params {:companies_vendor_id ""
                                                                                     :file ""}})
require "http/client"

url = "{{baseUrl}}/vendor_product_price_files"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/x-www-form-urlencoded"
}
reqBody = "companies_vendor_id=&file="

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}}/vendor_product_price_files"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new FormUrlEncodedContent(new Dictionary
    {
        { "companies_vendor_id", "" },
        { "file", "" },
    }),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/vendor_product_price_files");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/x-www-form-urlencoded");
request.AddParameter("application/x-www-form-urlencoded", "companies_vendor_id=&file=", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/vendor_product_price_files"

	payload := strings.NewReader("companies_vendor_id=&file=")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{apiKey}}")
	req.Header.Add("content-type", "application/x-www-form-urlencoded")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/vendor_product_price_files HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/x-www-form-urlencoded
Host: example.com
Content-Length: 26

companies_vendor_id=&file=
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/vendor_product_price_files")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/x-www-form-urlencoded")
  .setBody("companies_vendor_id=&file=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/vendor_product_price_files"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/x-www-form-urlencoded")
    .method("POST", HttpRequest.BodyPublishers.ofString("companies_vendor_id=&file="))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/x-www-form-urlencoded");
RequestBody body = RequestBody.create(mediaType, "companies_vendor_id=&file=");
Request request = new Request.Builder()
  .url("{{baseUrl}}/vendor_product_price_files")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/x-www-form-urlencoded")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/vendor_product_price_files")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/x-www-form-urlencoded")
  .body("companies_vendor_id=&file=")
  .asString();
const data = 'companies_vendor_id=&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}}/vendor_product_price_files');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/x-www-form-urlencoded');

xhr.send(data);
import axios from 'axios';

const encodedParams = new URLSearchParams();
encodedParams.set('companies_vendor_id', '');
encodedParams.set('file', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/vendor_product_price_files',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  data: encodedParams,
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/vendor_product_price_files';
const options = {
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  body: new URLSearchParams({companies_vendor_id: '', file: ''})
};

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}}/vendor_product_price_files',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  data: {
    companies_vendor_id: '',
    file: ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/x-www-form-urlencoded")
val body = RequestBody.create(mediaType, "companies_vendor_id=&file=")
val request = Request.Builder()
  .url("{{baseUrl}}/vendor_product_price_files")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/x-www-form-urlencoded")
  .build()

val response = client.newCall(request).execute()
const qs = require('querystring');
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/vendor_product_price_files',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  }
};

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(qs.stringify({companies_vendor_id: '', file: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/vendor_product_price_files',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  form: {companies_vendor_id: '', 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}}/vendor_product_price_files');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/x-www-form-urlencoded'
});

req.form({
  companies_vendor_id: '',
  file: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;
const { URLSearchParams } = require('url');

const encodedParams = new URLSearchParams();
encodedParams.set('companies_vendor_id', '');
encodedParams.set('file', '');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/vendor_product_price_files',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  data: encodedParams,
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const { URLSearchParams } = require('url');
const fetch = require('node-fetch');

const encodedParams = new URLSearchParams();
encodedParams.set('companies_vendor_id', '');
encodedParams.set('file', '');

const url = '{{baseUrl}}/vendor_product_price_files';
const options = {
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/x-www-form-urlencoded'
  },
  body: encodedParams
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/x-www-form-urlencoded" };

NSMutableData *postData = [[NSMutableData alloc] initWithData:[@"companies_vendor_id=" dataUsingEncoding:NSUTF8StringEncoding]];
[postData appendData:[@"&file=" dataUsingEncoding:NSUTF8StringEncoding]];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/vendor_product_price_files"]
                                                       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}}/vendor_product_price_files" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/x-www-form-urlencoded");
] in
let body = Cohttp_lwt_body.of_string "companies_vendor_id=&file=" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/vendor_product_price_files",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => "companies_vendor_id=&file=",
  CURLOPT_HTTPHEADER => [
    "content-type: application/x-www-form-urlencoded",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/vendor_product_price_files', [
  'form_params' => [
    'companies_vendor_id' => '',
    'file' => ''
  ],
  'headers' => [
    'content-type' => 'application/x-www-form-urlencoded',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/vendor_product_price_files');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/x-www-form-urlencoded'
]);

$request->setContentType('application/x-www-form-urlencoded');
$request->setPostFields([
  'companies_vendor_id' => '',
  'file' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(new http\QueryString([
  'companies_vendor_id' => '',
  'file' => ''
]));

$request->setRequestUrl('{{baseUrl}}/vendor_product_price_files');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/x-www-form-urlencoded'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/x-www-form-urlencoded")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/vendor_product_price_files' -Method POST -Headers $headers -ContentType 'application/x-www-form-urlencoded' -Body 'companies_vendor_id=&file='
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/x-www-form-urlencoded")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/vendor_product_price_files' -Method POST -Headers $headers -ContentType 'application/x-www-form-urlencoded' -Body 'companies_vendor_id=&file='
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "companies_vendor_id=&file="

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/x-www-form-urlencoded"
}

conn.request("POST", "/baseUrl/vendor_product_price_files", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/vendor_product_price_files"

payload = {
    "companies_vendor_id": "",
    "file": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/x-www-form-urlencoded"
}

response = requests.post(url, data=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/vendor_product_price_files"

payload <- "companies_vendor_id=&file="

encode <- "form"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/x-www-form-urlencoded"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/vendor_product_price_files")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/x-www-form-urlencoded'
request.body = "companies_vendor_id=&file="

response = http.request(request)
puts response.read_body
require 'faraday'

data = {
  :companies_vendor_id => "",
  :file => "",
}

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/x-www-form-urlencoded'}
)

response = conn.post('/baseUrl/vendor_product_price_files') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = URI.encode_www_form(data)
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/vendor_product_price_files";

    let payload = json!({
        "companies_vendor_id": "",
        "file": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{apiKey}}".parse().unwrap());
    headers.insert("content-type", "application/x-www-form-urlencoded".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .form(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/vendor_product_price_files \
  --header 'content-type: application/x-www-form-urlencoded' \
  --header 'x-auth-token: {{apiKey}}' \
  --data companies_vendor_id= \
  --data file=
http --form POST {{baseUrl}}/vendor_product_price_files \
  content-type:application/x-www-form-urlencoded \
  x-auth-token:'{{apiKey}}' \
  companies_vendor_id='' \
  file=''
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/x-www-form-urlencoded' \
  --body-data 'companies_vendor_id=&file=' \
  --output-document \
  - {{baseUrl}}/vendor_product_price_files
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/x-www-form-urlencoded"
]

let postData = NSMutableData(data: "companies_vendor_id=".data(using: String.Encoding.utf8)!)
postData.append("&file=".data(using: String.Encoding.utf8)!)

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/vendor_product_price_files")! 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 vendor products
{{baseUrl}}/vendor_products
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/vendor_products");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/vendor_products" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/vendor_products"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/vendor_products"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/vendor_products");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/vendor_products"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/vendor_products HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/vendor_products")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/vendor_products"))
    .header("x-auth-token", "{{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}}/vendor_products")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/vendor_products")
  .header("x-auth-token", "{{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}}/vendor_products');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/vendor_products',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/vendor_products';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/vendor_products',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/vendor_products")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/vendor_products',
  headers: {
    'x-auth-token': '{{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}}/vendor_products',
  headers: {'x-auth-token': '{{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}}/vendor_products');

req.headers({
  'x-auth-token': '{{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}}/vendor_products',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/vendor_products';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/vendor_products"]
                                                       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}}/vendor_products" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/vendor_products",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/vendor_products', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/vendor_products');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/vendor_products');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/vendor_products' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/vendor_products' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/vendor_products", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/vendor_products"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/vendor_products"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/vendor_products")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/vendor_products') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/vendor_products";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/vendor_products \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/vendor_products \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/vendor_products
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/vendor_products")! 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 View single vendor product
{{baseUrl}}/vendor_products/:vendor_product_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

vendor_product_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/vendor_products/:vendor_product_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/vendor_products/:vendor_product_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/vendor_products/:vendor_product_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/vendor_products/:vendor_product_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/vendor_products/:vendor_product_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/vendor_products/:vendor_product_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/vendor_products/:vendor_product_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/vendor_products/:vendor_product_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/vendor_products/:vendor_product_id"))
    .header("x-auth-token", "{{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}}/vendor_products/:vendor_product_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/vendor_products/:vendor_product_id")
  .header("x-auth-token", "{{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}}/vendor_products/:vendor_product_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/vendor_products/:vendor_product_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/vendor_products/:vendor_product_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/vendor_products/:vendor_product_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/vendor_products/:vendor_product_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/vendor_products/:vendor_product_id',
  headers: {
    'x-auth-token': '{{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}}/vendor_products/:vendor_product_id',
  headers: {'x-auth-token': '{{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}}/vendor_products/:vendor_product_id');

req.headers({
  'x-auth-token': '{{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}}/vendor_products/:vendor_product_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/vendor_products/:vendor_product_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/vendor_products/:vendor_product_id"]
                                                       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}}/vendor_products/:vendor_product_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/vendor_products/:vendor_product_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/vendor_products/:vendor_product_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/vendor_products/:vendor_product_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/vendor_products/:vendor_product_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/vendor_products/:vendor_product_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/vendor_products/:vendor_product_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/vendor_products/:vendor_product_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/vendor_products/:vendor_product_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/vendor_products/:vendor_product_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/vendor_products/:vendor_product_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/vendor_products/:vendor_product_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/vendor_products/:vendor_product_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/vendor_products/:vendor_product_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/vendor_products/:vendor_product_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/vendor_products/:vendor_product_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/vendor_products/:vendor_product_id")! 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 a new vendor
{{baseUrl}}/vendors
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/vendors");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/vendors" {:headers {:x-auth-token "{{apiKey}}"}
                                                    :content-type :json
                                                    :form-params {:country_id ""
                                                                  :cvr ""
                                                                  :email ""
                                                                  :identifier ""
                                                                  :is_custom false
                                                                  :name ""}})
require "http/client"

url = "{{baseUrl}}/vendors"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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}}/vendors"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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}}/vendors");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/vendors"

	payload := strings.NewReader("{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/vendors HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 106

{
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/vendors")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/vendors"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/vendors")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/vendors")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  country_id: '',
  cvr: '',
  email: '',
  identifier: '',
  is_custom: false,
  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}}/vendors');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/vendors',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {country_id: '', cvr: '', email: '', identifier: '', is_custom: false, name: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/vendors';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"country_id":"","cvr":"","email":"","identifier":"","is_custom":false,"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}}/vendors',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "country_id": "",\n  "cvr": "",\n  "email": "",\n  "identifier": "",\n  "is_custom": false,\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  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/vendors")
  .post(body)
  .addHeader("x-auth-token", "{{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/vendors',
  headers: {
    'x-auth-token': '{{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({country_id: '', cvr: '', email: '', identifier: '', is_custom: false, name: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/vendors',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {country_id: '', cvr: '', email: '', identifier: '', is_custom: false, 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}}/vendors');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  country_id: '',
  cvr: '',
  email: '',
  identifier: '',
  is_custom: false,
  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}}/vendors',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {country_id: '', cvr: '', email: '', identifier: '', is_custom: false, name: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/vendors';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"country_id":"","cvr":"","email":"","identifier":"","is_custom":false,"name":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"country_id": @"",
                              @"cvr": @"",
                              @"email": @"",
                              @"identifier": @"",
                              @"is_custom": @NO,
                              @"name": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/vendors"]
                                                       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}}/vendors" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/vendors",
  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([
    'country_id' => '',
    'cvr' => '',
    'email' => '',
    'identifier' => '',
    'is_custom' => null,
    'name' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/vendors', [
  'body' => '{
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/vendors');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'country_id' => '',
  'cvr' => '',
  'email' => '',
  'identifier' => '',
  'is_custom' => null,
  'name' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'country_id' => '',
  'cvr' => '',
  'email' => '',
  'identifier' => '',
  'is_custom' => null,
  'name' => ''
]));
$request->setRequestUrl('{{baseUrl}}/vendors');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/vendors' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/vendors' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/vendors", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/vendors"

payload = {
    "country_id": "",
    "cvr": "",
    "email": "",
    "identifier": "",
    "is_custom": False,
    "name": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/vendors"

payload <- "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/vendors")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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/vendors') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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}}/vendors";

    let payload = json!({
        "country_id": "",
        "cvr": "",
        "email": "",
        "identifier": "",
        "is_custom": false,
        "name": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/vendors \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}'
echo '{
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}' |  \
  http POST {{baseUrl}}/vendors \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "country_id": "",\n  "cvr": "",\n  "email": "",\n  "identifier": "",\n  "is_custom": false,\n  "name": ""\n}' \
  --output-document \
  - {{baseUrl}}/vendors
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/vendors")! 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 Delete a vendor
{{baseUrl}}/vendors/:vendor_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

vendor_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/vendors/:vendor_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/vendors/:vendor_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/vendors/:vendor_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/vendors/:vendor_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/vendors/:vendor_id");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/vendors/:vendor_id"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/vendors/:vendor_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/vendors/:vendor_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/vendors/:vendor_id"))
    .header("x-auth-token", "{{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}}/vendors/:vendor_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/vendors/:vendor_id")
  .header("x-auth-token", "{{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}}/vendors/:vendor_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/vendors/:vendor_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/vendors/:vendor_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{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}}/vendors/:vendor_id',
  method: 'DELETE',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/vendors/:vendor_id")
  .delete(null)
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/vendors/:vendor_id',
  headers: {
    'x-auth-token': '{{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}}/vendors/:vendor_id',
  headers: {'x-auth-token': '{{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}}/vendors/:vendor_id');

req.headers({
  'x-auth-token': '{{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}}/vendors/:vendor_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/vendors/:vendor_id';
const options = {method: 'DELETE', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/vendors/:vendor_id"]
                                                       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}}/vendors/:vendor_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/vendors/:vendor_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/vendors/:vendor_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/vendors/:vendor_id');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/vendors/:vendor_id');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/vendors/:vendor_id' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/vendors/:vendor_id' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/vendors/:vendor_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/vendors/:vendor_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/vendors/:vendor_id"

response <- VERB("DELETE", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/vendors/:vendor_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/vendors/:vendor_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/vendors/:vendor_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/vendors/:vendor_id \
  --header 'x-auth-token: {{apiKey}}'
http DELETE {{baseUrl}}/vendors/:vendor_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/vendors/:vendor_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/vendors/:vendor_id")! 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()
PUT Edit a vendor
{{baseUrl}}/vendors/:vendor_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

vendor_id
BODY json

{
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/vendors/:vendor_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/vendors/:vendor_id" {:headers {:x-auth-token "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:country_id ""
                                                                            :cvr ""
                                                                            :email ""
                                                                            :identifier ""
                                                                            :is_custom false
                                                                            :name ""}})
require "http/client"

url = "{{baseUrl}}/vendors/:vendor_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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}}/vendors/:vendor_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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}}/vendors/:vendor_id");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/vendors/:vendor_id"

	payload := strings.NewReader("{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("x-auth-token", "{{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/vendors/:vendor_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 106

{
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/vendors/:vendor_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/vendors/:vendor_id"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/vendors/:vendor_id")
  .put(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/vendors/:vendor_id")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  country_id: '',
  cvr: '',
  email: '',
  identifier: '',
  is_custom: false,
  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}}/vendors/:vendor_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/vendors/:vendor_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {country_id: '', cvr: '', email: '', identifier: '', is_custom: false, name: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/vendors/:vendor_id';
const options = {
  method: 'PUT',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"country_id":"","cvr":"","email":"","identifier":"","is_custom":false,"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}}/vendors/:vendor_id',
  method: 'PUT',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "country_id": "",\n  "cvr": "",\n  "email": "",\n  "identifier": "",\n  "is_custom": false,\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  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/vendors/:vendor_id")
  .put(body)
  .addHeader("x-auth-token", "{{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/vendors/:vendor_id',
  headers: {
    'x-auth-token': '{{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({country_id: '', cvr: '', email: '', identifier: '', is_custom: false, name: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/vendors/:vendor_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {country_id: '', cvr: '', email: '', identifier: '', is_custom: false, 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}}/vendors/:vendor_id');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  country_id: '',
  cvr: '',
  email: '',
  identifier: '',
  is_custom: false,
  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}}/vendors/:vendor_id',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {country_id: '', cvr: '', email: '', identifier: '', is_custom: false, name: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/vendors/:vendor_id';
const options = {
  method: 'PUT',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"country_id":"","cvr":"","email":"","identifier":"","is_custom":false,"name":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"country_id": @"",
                              @"cvr": @"",
                              @"email": @"",
                              @"identifier": @"",
                              @"is_custom": @NO,
                              @"name": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/vendors/:vendor_id"]
                                                       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}}/vendors/:vendor_id" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/vendors/:vendor_id",
  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([
    'country_id' => '',
    'cvr' => '',
    'email' => '',
    'identifier' => '',
    'is_custom' => null,
    'name' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/vendors/:vendor_id', [
  'body' => '{
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/vendors/:vendor_id');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'country_id' => '',
  'cvr' => '',
  'email' => '',
  'identifier' => '',
  'is_custom' => null,
  'name' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'country_id' => '',
  'cvr' => '',
  'email' => '',
  'identifier' => '',
  'is_custom' => null,
  'name' => ''
]));
$request->setRequestUrl('{{baseUrl}}/vendors/:vendor_id');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/vendors/:vendor_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/vendors/:vendor_id' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/vendors/:vendor_id", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/vendors/:vendor_id"

payload = {
    "country_id": "",
    "cvr": "",
    "email": "",
    "identifier": "",
    "is_custom": False,
    "name": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/vendors/:vendor_id"

payload <- "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\n  \"name\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/vendors/:vendor_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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/vendors/:vendor_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"country_id\": \"\",\n  \"cvr\": \"\",\n  \"email\": \"\",\n  \"identifier\": \"\",\n  \"is_custom\": false,\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}}/vendors/:vendor_id";

    let payload = json!({
        "country_id": "",
        "cvr": "",
        "email": "",
        "identifier": "",
        "is_custom": false,
        "name": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/vendors/:vendor_id \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}'
echo '{
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
}' |  \
  http PUT {{baseUrl}}/vendors/:vendor_id \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "country_id": "",\n  "cvr": "",\n  "email": "",\n  "identifier": "",\n  "is_custom": false,\n  "name": ""\n}' \
  --output-document \
  - {{baseUrl}}/vendors/:vendor_id
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "country_id": "",
  "cvr": "",
  "email": "",
  "identifier": "",
  "is_custom": false,
  "name": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/vendors/:vendor_id")! 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 Get a list of vendors
{{baseUrl}}/vendors
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/vendors");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/vendors" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/vendors"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/vendors"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/vendors");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/vendors"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/vendors HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/vendors")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/vendors"))
    .header("x-auth-token", "{{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}}/vendors")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/vendors")
  .header("x-auth-token", "{{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}}/vendors');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/vendors',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/vendors';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/vendors',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/vendors")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/vendors',
  headers: {
    'x-auth-token': '{{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}}/vendors',
  headers: {'x-auth-token': '{{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}}/vendors');

req.headers({
  'x-auth-token': '{{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}}/vendors',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/vendors';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/vendors"]
                                                       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}}/vendors" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/vendors",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/vendors', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/vendors');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/vendors');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/vendors' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/vendors' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/vendors", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/vendors"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/vendors"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/vendors")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/vendors') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/vendors";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/vendors \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/vendors \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/vendors
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/vendors")! 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 a vendor
{{baseUrl}}/vendors/:vendor_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

vendor_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/vendors/:vendor_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/vendors/:vendor_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/vendors/:vendor_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/vendors/:vendor_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/vendors/:vendor_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/vendors/:vendor_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/vendors/:vendor_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/vendors/:vendor_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/vendors/:vendor_id"))
    .header("x-auth-token", "{{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}}/vendors/:vendor_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/vendors/:vendor_id")
  .header("x-auth-token", "{{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}}/vendors/:vendor_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/vendors/:vendor_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/vendors/:vendor_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/vendors/:vendor_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/vendors/:vendor_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/vendors/:vendor_id',
  headers: {
    'x-auth-token': '{{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}}/vendors/:vendor_id',
  headers: {'x-auth-token': '{{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}}/vendors/:vendor_id');

req.headers({
  'x-auth-token': '{{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}}/vendors/:vendor_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/vendors/:vendor_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/vendors/:vendor_id"]
                                                       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}}/vendors/:vendor_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/vendors/:vendor_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/vendors/:vendor_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/vendors/:vendor_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/vendors/:vendor_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/vendors/:vendor_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/vendors/:vendor_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/vendors/:vendor_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/vendors/:vendor_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/vendors/:vendor_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/vendors/:vendor_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/vendors/:vendor_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/vendors/:vendor_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/vendors/:vendor_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/vendors/:vendor_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/vendors/:vendor_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/vendors/:vendor_id")! 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 Download salary file
{{baseUrl}}/wages/downloadSalaryFile
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/wages/downloadSalaryFile");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/wages/downloadSalaryFile" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/wages/downloadSalaryFile"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/wages/downloadSalaryFile"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/wages/downloadSalaryFile");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/wages/downloadSalaryFile"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/wages/downloadSalaryFile HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/wages/downloadSalaryFile")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/wages/downloadSalaryFile"))
    .header("x-auth-token", "{{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}}/wages/downloadSalaryFile")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/wages/downloadSalaryFile")
  .header("x-auth-token", "{{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}}/wages/downloadSalaryFile');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/wages/downloadSalaryFile',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/wages/downloadSalaryFile';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/wages/downloadSalaryFile',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/wages/downloadSalaryFile")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/wages/downloadSalaryFile',
  headers: {
    'x-auth-token': '{{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}}/wages/downloadSalaryFile',
  headers: {'x-auth-token': '{{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}}/wages/downloadSalaryFile');

req.headers({
  'x-auth-token': '{{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}}/wages/downloadSalaryFile',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/wages/downloadSalaryFile';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/wages/downloadSalaryFile"]
                                                       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}}/wages/downloadSalaryFile" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/wages/downloadSalaryFile",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/wages/downloadSalaryFile', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/wages/downloadSalaryFile');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/wages/downloadSalaryFile');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/wages/downloadSalaryFile' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/wages/downloadSalaryFile' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/wages/downloadSalaryFile", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/wages/downloadSalaryFile"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/wages/downloadSalaryFile"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/wages/downloadSalaryFile")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/wages/downloadSalaryFile') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/wages/downloadSalaryFile";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/wages/downloadSalaryFile \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/wages/downloadSalaryFile \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/wages/downloadSalaryFile
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/wages/downloadSalaryFile")! 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 wall comment
{{baseUrl}}/wall_comments
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "message": "",
  "wall_post_id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/wall_comments");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"message\": \"\",\n  \"wall_post_id\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/wall_comments" {:headers {:x-auth-token "{{apiKey}}"}
                                                          :content-type :json
                                                          :form-params {:message ""
                                                                        :wall_post_id ""}})
require "http/client"

url = "{{baseUrl}}/wall_comments"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"message\": \"\",\n  \"wall_post_id\": \"\"\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}}/wall_comments"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"message\": \"\",\n  \"wall_post_id\": \"\"\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}}/wall_comments");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"message\": \"\",\n  \"wall_post_id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/wall_comments"

	payload := strings.NewReader("{\n  \"message\": \"\",\n  \"wall_post_id\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/wall_comments HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 41

{
  "message": "",
  "wall_post_id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/wall_comments")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"message\": \"\",\n  \"wall_post_id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/wall_comments"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"message\": \"\",\n  \"wall_post_id\": \"\"\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  \"message\": \"\",\n  \"wall_post_id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/wall_comments")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/wall_comments")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"message\": \"\",\n  \"wall_post_id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  message: '',
  wall_post_id: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/wall_comments');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/wall_comments',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {message: '', wall_post_id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/wall_comments';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"message":"","wall_post_id":""}'
};

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}}/wall_comments',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "message": "",\n  "wall_post_id": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"message\": \"\",\n  \"wall_post_id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/wall_comments")
  .post(body)
  .addHeader("x-auth-token", "{{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/wall_comments',
  headers: {
    'x-auth-token': '{{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({message: '', wall_post_id: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/wall_comments',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {message: '', wall_post_id: ''},
  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}}/wall_comments');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  message: '',
  wall_post_id: ''
});

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}}/wall_comments',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {message: '', wall_post_id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/wall_comments';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"message":"","wall_post_id":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"message": @"",
                              @"wall_post_id": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/wall_comments"]
                                                       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}}/wall_comments" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"message\": \"\",\n  \"wall_post_id\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/wall_comments",
  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([
    'message' => '',
    'wall_post_id' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/wall_comments', [
  'body' => '{
  "message": "",
  "wall_post_id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/wall_comments');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'message' => '',
  'wall_post_id' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'message' => '',
  'wall_post_id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/wall_comments');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/wall_comments' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "message": "",
  "wall_post_id": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/wall_comments' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "message": "",
  "wall_post_id": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"message\": \"\",\n  \"wall_post_id\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/wall_comments", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/wall_comments"

payload = {
    "message": "",
    "wall_post_id": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/wall_comments"

payload <- "{\n  \"message\": \"\",\n  \"wall_post_id\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/wall_comments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"message\": \"\",\n  \"wall_post_id\": \"\"\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/wall_comments') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"message\": \"\",\n  \"wall_post_id\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/wall_comments";

    let payload = json!({
        "message": "",
        "wall_post_id": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/wall_comments \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "message": "",
  "wall_post_id": ""
}'
echo '{
  "message": "",
  "wall_post_id": ""
}' |  \
  http POST {{baseUrl}}/wall_comments \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "message": "",\n  "wall_post_id": ""\n}' \
  --output-document \
  - {{baseUrl}}/wall_comments
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "message": "",
  "wall_post_id": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/wall_comments")! 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 View wall comment
{{baseUrl}}/wall_comments/:wall_comment_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

wall_comment_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/wall_comments/:wall_comment_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/wall_comments/:wall_comment_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/wall_comments/:wall_comment_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/wall_comments/:wall_comment_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/wall_comments/:wall_comment_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/wall_comments/:wall_comment_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/wall_comments/:wall_comment_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/wall_comments/:wall_comment_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/wall_comments/:wall_comment_id"))
    .header("x-auth-token", "{{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}}/wall_comments/:wall_comment_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/wall_comments/:wall_comment_id")
  .header("x-auth-token", "{{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}}/wall_comments/:wall_comment_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/wall_comments/:wall_comment_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/wall_comments/:wall_comment_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/wall_comments/:wall_comment_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/wall_comments/:wall_comment_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/wall_comments/:wall_comment_id',
  headers: {
    'x-auth-token': '{{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}}/wall_comments/:wall_comment_id',
  headers: {'x-auth-token': '{{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}}/wall_comments/:wall_comment_id');

req.headers({
  'x-auth-token': '{{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}}/wall_comments/:wall_comment_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/wall_comments/:wall_comment_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/wall_comments/:wall_comment_id"]
                                                       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}}/wall_comments/:wall_comment_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/wall_comments/:wall_comment_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/wall_comments/:wall_comment_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/wall_comments/:wall_comment_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/wall_comments/:wall_comment_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/wall_comments/:wall_comment_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/wall_comments/:wall_comment_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/wall_comments/:wall_comment_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/wall_comments/:wall_comment_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/wall_comments/:wall_comment_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/wall_comments/:wall_comment_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/wall_comments/:wall_comment_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/wall_comments/:wall_comment_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/wall_comments/:wall_comment_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/wall_comments/:wall_comment_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/wall_comments/:wall_comment_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/wall_comments/:wall_comment_id")! 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 a wall post
{{baseUrl}}/wall_posts
HEADERS

X-Auth-Token
{{apiKey}}
BODY json

{
  "message": "",
  "project_id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/wall_posts");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"message\": \"\",\n  \"project_id\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/wall_posts" {:headers {:x-auth-token "{{apiKey}}"}
                                                       :content-type :json
                                                       :form-params {:message ""
                                                                     :project_id ""}})
require "http/client"

url = "{{baseUrl}}/wall_posts"
headers = HTTP::Headers{
  "x-auth-token" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"message\": \"\",\n  \"project_id\": \"\"\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}}/wall_posts"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"message\": \"\",\n  \"project_id\": \"\"\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}}/wall_posts");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth-token", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"message\": \"\",\n  \"project_id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/wall_posts"

	payload := strings.NewReader("{\n  \"message\": \"\",\n  \"project_id\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("x-auth-token", "{{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/wall_posts HTTP/1.1
X-Auth-Token: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 39

{
  "message": "",
  "project_id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/wall_posts")
  .setHeader("x-auth-token", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"message\": \"\",\n  \"project_id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/wall_posts"))
    .header("x-auth-token", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"message\": \"\",\n  \"project_id\": \"\"\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  \"message\": \"\",\n  \"project_id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/wall_posts")
  .post(body)
  .addHeader("x-auth-token", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/wall_posts")
  .header("x-auth-token", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"message\": \"\",\n  \"project_id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  message: '',
  project_id: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/wall_posts');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/wall_posts',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {message: '', project_id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/wall_posts';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"message":"","project_id":""}'
};

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}}/wall_posts',
  method: 'POST',
  headers: {
    'x-auth-token': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "message": "",\n  "project_id": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"message\": \"\",\n  \"project_id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/wall_posts")
  .post(body)
  .addHeader("x-auth-token", "{{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/wall_posts',
  headers: {
    'x-auth-token': '{{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({message: '', project_id: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/wall_posts',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: {message: '', project_id: ''},
  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}}/wall_posts');

req.headers({
  'x-auth-token': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  message: '',
  project_id: ''
});

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}}/wall_posts',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  data: {message: '', project_id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/wall_posts';
const options = {
  method: 'POST',
  headers: {'x-auth-token': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"message":"","project_id":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"message": @"",
                              @"project_id": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/wall_posts"]
                                                       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}}/wall_posts" in
let headers = Header.add_list (Header.init ()) [
  ("x-auth-token", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"message\": \"\",\n  \"project_id\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/wall_posts",
  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([
    'message' => '',
    'project_id' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/wall_posts', [
  'body' => '{
  "message": "",
  "project_id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/wall_posts');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'message' => '',
  'project_id' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'message' => '',
  'project_id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/wall_posts');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/wall_posts' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "message": "",
  "project_id": ""
}'
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/wall_posts' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "message": "",
  "project_id": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"message\": \"\",\n  \"project_id\": \"\"\n}"

headers = {
    'x-auth-token': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/wall_posts", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/wall_posts"

payload = {
    "message": "",
    "project_id": ""
}
headers = {
    "x-auth-token": "{{apiKey}}",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/wall_posts"

payload <- "{\n  \"message\": \"\",\n  \"project_id\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/wall_posts")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth-token"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"message\": \"\",\n  \"project_id\": \"\"\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/wall_posts') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
  req.body = "{\n  \"message\": \"\",\n  \"project_id\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/wall_posts";

    let payload = json!({
        "message": "",
        "project_id": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/wall_posts \
  --header 'content-type: application/json' \
  --header 'x-auth-token: {{apiKey}}' \
  --data '{
  "message": "",
  "project_id": ""
}'
echo '{
  "message": "",
  "project_id": ""
}' |  \
  http POST {{baseUrl}}/wall_posts \
  content-type:application/json \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth-token: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "message": "",\n  "project_id": ""\n}' \
  --output-document \
  - {{baseUrl}}/wall_posts
import Foundation

let headers = [
  "x-auth-token": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "message": "",
  "project_id": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/wall_posts")! 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 See wall comments to a wall post
{{baseUrl}}/wall_posts/:wall_post_id/wall_comments
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

wall_post_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/wall_posts/:wall_post_id/wall_comments");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/wall_posts/:wall_post_id/wall_comments" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/wall_posts/:wall_post_id/wall_comments"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/wall_posts/:wall_post_id/wall_comments"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/wall_posts/:wall_post_id/wall_comments");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/wall_posts/:wall_post_id/wall_comments"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/wall_posts/:wall_post_id/wall_comments HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/wall_posts/:wall_post_id/wall_comments")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/wall_posts/:wall_post_id/wall_comments"))
    .header("x-auth-token", "{{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}}/wall_posts/:wall_post_id/wall_comments")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/wall_posts/:wall_post_id/wall_comments")
  .header("x-auth-token", "{{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}}/wall_posts/:wall_post_id/wall_comments');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/wall_posts/:wall_post_id/wall_comments',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/wall_posts/:wall_post_id/wall_comments';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/wall_posts/:wall_post_id/wall_comments',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/wall_posts/:wall_post_id/wall_comments")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/wall_posts/:wall_post_id/wall_comments',
  headers: {
    'x-auth-token': '{{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}}/wall_posts/:wall_post_id/wall_comments',
  headers: {'x-auth-token': '{{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}}/wall_posts/:wall_post_id/wall_comments');

req.headers({
  'x-auth-token': '{{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}}/wall_posts/:wall_post_id/wall_comments',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/wall_posts/:wall_post_id/wall_comments';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/wall_posts/:wall_post_id/wall_comments"]
                                                       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}}/wall_posts/:wall_post_id/wall_comments" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/wall_posts/:wall_post_id/wall_comments",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/wall_posts/:wall_post_id/wall_comments', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/wall_posts/:wall_post_id/wall_comments');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/wall_posts/:wall_post_id/wall_comments');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/wall_posts/:wall_post_id/wall_comments' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/wall_posts/:wall_post_id/wall_comments' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/wall_posts/:wall_post_id/wall_comments", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/wall_posts/:wall_post_id/wall_comments"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/wall_posts/:wall_post_id/wall_comments"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/wall_posts/:wall_post_id/wall_comments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/wall_posts/:wall_post_id/wall_comments') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/wall_posts/:wall_post_id/wall_comments";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/wall_posts/:wall_post_id/wall_comments \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/wall_posts/:wall_post_id/wall_comments \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/wall_posts/:wall_post_id/wall_comments
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/wall_posts/:wall_post_id/wall_comments")! 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 View list of wall posts
{{baseUrl}}/wall_posts
HEADERS

X-Auth-Token
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/wall_posts");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/wall_posts" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/wall_posts"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/wall_posts"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/wall_posts");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/wall_posts"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/wall_posts HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/wall_posts")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/wall_posts"))
    .header("x-auth-token", "{{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}}/wall_posts")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/wall_posts")
  .header("x-auth-token", "{{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}}/wall_posts');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/wall_posts',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/wall_posts';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/wall_posts',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/wall_posts")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/wall_posts',
  headers: {
    'x-auth-token': '{{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}}/wall_posts',
  headers: {'x-auth-token': '{{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}}/wall_posts');

req.headers({
  'x-auth-token': '{{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}}/wall_posts',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/wall_posts';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/wall_posts"]
                                                       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}}/wall_posts" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/wall_posts",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/wall_posts', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/wall_posts');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/wall_posts');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/wall_posts' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/wall_posts' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/wall_posts", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/wall_posts"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/wall_posts"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/wall_posts")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/wall_posts') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/wall_posts";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/wall_posts \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/wall_posts \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/wall_posts
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/wall_posts")! 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 View wall post
{{baseUrl}}/wall_posts/:wall_post_id
HEADERS

X-Auth-Token
{{apiKey}}
QUERY PARAMS

wall_post_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/wall_posts/:wall_post_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth-token: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/wall_posts/:wall_post_id" {:headers {:x-auth-token "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/wall_posts/:wall_post_id"
headers = HTTP::Headers{
  "x-auth-token" => "{{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}}/wall_posts/:wall_post_id"),
    Headers =
    {
        { "x-auth-token", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/wall_posts/:wall_post_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth-token", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/wall_posts/:wall_post_id"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth-token", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/wall_posts/:wall_post_id HTTP/1.1
X-Auth-Token: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/wall_posts/:wall_post_id")
  .setHeader("x-auth-token", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/wall_posts/:wall_post_id"))
    .header("x-auth-token", "{{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}}/wall_posts/:wall_post_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/wall_posts/:wall_post_id")
  .header("x-auth-token", "{{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}}/wall_posts/:wall_post_id');
xhr.setRequestHeader('x-auth-token', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/wall_posts/:wall_post_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/wall_posts/:wall_post_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{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}}/wall_posts/:wall_post_id',
  method: 'GET',
  headers: {
    'x-auth-token': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/wall_posts/:wall_post_id")
  .get()
  .addHeader("x-auth-token", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/wall_posts/:wall_post_id',
  headers: {
    'x-auth-token': '{{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}}/wall_posts/:wall_post_id',
  headers: {'x-auth-token': '{{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}}/wall_posts/:wall_post_id');

req.headers({
  'x-auth-token': '{{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}}/wall_posts/:wall_post_id',
  headers: {'x-auth-token': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/wall_posts/:wall_post_id';
const options = {method: 'GET', headers: {'x-auth-token': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"x-auth-token": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/wall_posts/:wall_post_id"]
                                                       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}}/wall_posts/:wall_post_id" in
let headers = Header.add (Header.init ()) "x-auth-token" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/wall_posts/:wall_post_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-auth-token: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/wall_posts/:wall_post_id', [
  'headers' => [
    'x-auth-token' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/wall_posts/:wall_post_id');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/wall_posts/:wall_post_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth-token' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/wall_posts/:wall_post_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth-token", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/wall_posts/:wall_post_id' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth-token': "{{apiKey}}" }

conn.request("GET", "/baseUrl/wall_posts/:wall_post_id", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/wall_posts/:wall_post_id"

headers = {"x-auth-token": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/wall_posts/:wall_post_id"

response <- VERB("GET", url, add_headers('x-auth-token' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/wall_posts/:wall_post_id")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth-token"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/wall_posts/:wall_post_id') do |req|
  req.headers['x-auth-token'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/wall_posts/:wall_post_id";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth-token", "{{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}}/wall_posts/:wall_post_id \
  --header 'x-auth-token: {{apiKey}}'
http GET {{baseUrl}}/wall_posts/:wall_post_id \
  x-auth-token:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth-token: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/wall_posts/:wall_post_id
import Foundation

let headers = ["x-auth-token": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/wall_posts/:wall_post_id")! 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()