PATCH Compromise app key (PATCH)
{{baseUrl}}/authentication/appkey
QUERY PARAMS

app_key
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/authentication/appkey?app_key=");

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

(client/patch "{{baseUrl}}/authentication/appkey" {:query-params {:app_key ""}})
require "http/client"

url = "{{baseUrl}}/authentication/appkey?app_key="

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

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

func main() {

	url := "{{baseUrl}}/authentication/appkey?app_key="

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

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

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

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

}
PATCH /baseUrl/authentication/appkey?app_key= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/authentication/appkey?app_key=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/authentication/appkey?app_key=")
  .patch(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/authentication/appkey?app_key=")
  .asString();
const data = null;

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

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

xhr.open('PATCH', '{{baseUrl}}/authentication/appkey?app_key=');

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/authentication/appkey',
  params: {app_key: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/authentication/appkey?app_key=';
const options = {method: 'PATCH'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/authentication/appkey?app_key=',
  method: 'PATCH',
  headers: {}
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/authentication/appkey?app_key=")
  .patch(null)
  .build()

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

const options = {
  method: 'PATCH',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/authentication/appkey?app_key=',
  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: 'PATCH',
  url: '{{baseUrl}}/authentication/appkey',
  qs: {app_key: ''}
};

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

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

const req = unirest('PATCH', '{{baseUrl}}/authentication/appkey');

req.query({
  app_key: ''
});

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

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/authentication/appkey',
  params: {app_key: ''}
};

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

const url = '{{baseUrl}}/authentication/appkey?app_key=';
const options = {method: 'PATCH'};

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}}/authentication/appkey?app_key="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PATCH"];

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

let uri = Uri.of_string "{{baseUrl}}/authentication/appkey?app_key=" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PATCH', '{{baseUrl}}/authentication/appkey?app_key=');

echo $response->getBody();
setUrl('{{baseUrl}}/authentication/appkey');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

$request->setQueryData([
  'app_key' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/authentication/appkey');
$request->setRequestMethod('PATCH');
$request->setQuery(new http\QueryString([
  'app_key' => ''
]));

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

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/authentication/appkey?app_key=' -Method PATCH 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/authentication/appkey?app_key=' -Method PATCH 
import http.client

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

conn.request("PATCH", "/baseUrl/authentication/appkey?app_key=")

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

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

url = "{{baseUrl}}/authentication/appkey"

querystring = {"app_key":""}

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

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

url <- "{{baseUrl}}/authentication/appkey"

queryString <- list(app_key = "")

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

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

url = URI("{{baseUrl}}/authentication/appkey?app_key=")

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

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

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

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

response = conn.patch('/baseUrl/authentication/appkey') do |req|
  req.params['app_key'] = ''
end

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

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

    let querystring = [
        ("app_key", ""),
    ];

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

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

    dbg!(results);
}
curl --request PATCH \
  --url '{{baseUrl}}/authentication/appkey?app_key='
http PATCH '{{baseUrl}}/authentication/appkey?app_key='
wget --quiet \
  --method PATCH \
  --output-document \
  - '{{baseUrl}}/authentication/appkey?app_key='
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/authentication/appkey?app_key=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PATCH"

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

dataTask.resume()
PATCH Compromise app key
{{baseUrl}}/appkey
QUERY PARAMS

app_key
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/appkey?app_key=");

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

(client/patch "{{baseUrl}}/appkey" {:query-params {:app_key ""}})
require "http/client"

url = "{{baseUrl}}/appkey?app_key="

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

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

func main() {

	url := "{{baseUrl}}/appkey?app_key="

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

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

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

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

}
PATCH /baseUrl/appkey?app_key= HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/appkey?app_key=")
  .patch(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/appkey?app_key=")
  .asString();
const data = null;

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

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

xhr.open('PATCH', '{{baseUrl}}/appkey?app_key=');

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/appkey',
  params: {app_key: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/appkey?app_key=';
const options = {method: 'PATCH'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/appkey?app_key=")
  .patch(null)
  .build()

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

const options = {
  method: 'PATCH',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/appkey?app_key=',
  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: 'PATCH', url: '{{baseUrl}}/appkey', qs: {app_key: ''}};

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

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

const req = unirest('PATCH', '{{baseUrl}}/appkey');

req.query({
  app_key: ''
});

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

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/appkey',
  params: {app_key: ''}
};

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

const url = '{{baseUrl}}/appkey?app_key=';
const options = {method: 'PATCH'};

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}}/appkey?app_key="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PATCH"];

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

let uri = Uri.of_string "{{baseUrl}}/appkey?app_key=" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PATCH', '{{baseUrl}}/appkey?app_key=');

echo $response->getBody();
setUrl('{{baseUrl}}/appkey');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

$request->setQueryData([
  'app_key' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/appkey');
$request->setRequestMethod('PATCH');
$request->setQuery(new http\QueryString([
  'app_key' => ''
]));

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

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

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

conn.request("PATCH", "/baseUrl/appkey?app_key=")

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

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

url = "{{baseUrl}}/appkey"

querystring = {"app_key":""}

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

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

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

queryString <- list(app_key = "")

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

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

url = URI("{{baseUrl}}/appkey?app_key=")

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

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

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

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

response = conn.patch('/baseUrl/appkey') do |req|
  req.params['app_key'] = ''
end

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

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

    let querystring = [
        ("app_key", ""),
    ];

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

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

    dbg!(results);
}
curl --request PATCH \
  --url '{{baseUrl}}/appkey?app_key='
http PATCH '{{baseUrl}}/appkey?app_key='
wget --quiet \
  --method PATCH \
  --output-document \
  - '{{baseUrl}}/appkey?app_key='
import Foundation

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

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

dataTask.resume()
PATCH Compromise auth key (PATCH)
{{baseUrl}}/authkey
QUERY PARAMS

auth_key
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/authkey?auth_key=");

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

(client/patch "{{baseUrl}}/authkey" {:query-params {:auth_key ""}})
require "http/client"

url = "{{baseUrl}}/authkey?auth_key="

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

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

func main() {

	url := "{{baseUrl}}/authkey?auth_key="

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

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

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

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

}
PATCH /baseUrl/authkey?auth_key= HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/authkey?auth_key=")
  .patch(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/authkey?auth_key=")
  .asString();
const data = null;

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

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

xhr.open('PATCH', '{{baseUrl}}/authkey?auth_key=');

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/authkey',
  params: {auth_key: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/authkey?auth_key=';
const options = {method: 'PATCH'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/authkey?auth_key=")
  .patch(null)
  .build()

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

const options = {
  method: 'PATCH',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/authkey?auth_key=',
  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: 'PATCH',
  url: '{{baseUrl}}/authkey',
  qs: {auth_key: ''}
};

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

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

const req = unirest('PATCH', '{{baseUrl}}/authkey');

req.query({
  auth_key: ''
});

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

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/authkey',
  params: {auth_key: ''}
};

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

const url = '{{baseUrl}}/authkey?auth_key=';
const options = {method: 'PATCH'};

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}}/authkey?auth_key="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PATCH"];

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

let uri = Uri.of_string "{{baseUrl}}/authkey?auth_key=" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PATCH', '{{baseUrl}}/authkey?auth_key=');

echo $response->getBody();
setUrl('{{baseUrl}}/authkey');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

$request->setQueryData([
  'auth_key' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/authkey');
$request->setRequestMethod('PATCH');
$request->setQuery(new http\QueryString([
  'auth_key' => ''
]));

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

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

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

conn.request("PATCH", "/baseUrl/authkey?auth_key=")

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

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

url = "{{baseUrl}}/authkey"

querystring = {"auth_key":""}

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

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

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

queryString <- list(auth_key = "")

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

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

url = URI("{{baseUrl}}/authkey?auth_key=")

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

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

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

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

response = conn.patch('/baseUrl/authkey') do |req|
  req.params['auth_key'] = ''
end

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

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

    let querystring = [
        ("auth_key", ""),
    ];

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

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

    dbg!(results);
}
curl --request PATCH \
  --url '{{baseUrl}}/authkey?auth_key='
http PATCH '{{baseUrl}}/authkey?auth_key='
wget --quiet \
  --method PATCH \
  --output-document \
  - '{{baseUrl}}/authkey?auth_key='
import Foundation

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

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

dataTask.resume()
PATCH Compromise auth key
{{baseUrl}}/authentication/authkey
QUERY PARAMS

auth_key
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/authentication/authkey?auth_key=");

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

(client/patch "{{baseUrl}}/authentication/authkey" {:query-params {:auth_key ""}})
require "http/client"

url = "{{baseUrl}}/authentication/authkey?auth_key="

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

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

func main() {

	url := "{{baseUrl}}/authentication/authkey?auth_key="

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

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

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

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

}
PATCH /baseUrl/authentication/authkey?auth_key= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/authentication/authkey?auth_key=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/authentication/authkey?auth_key=")
  .patch(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/authentication/authkey?auth_key=")
  .asString();
const data = null;

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

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

xhr.open('PATCH', '{{baseUrl}}/authentication/authkey?auth_key=');

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/authentication/authkey',
  params: {auth_key: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/authentication/authkey?auth_key=';
const options = {method: 'PATCH'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/authentication/authkey?auth_key=',
  method: 'PATCH',
  headers: {}
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/authentication/authkey?auth_key=")
  .patch(null)
  .build()

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

const options = {
  method: 'PATCH',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/authentication/authkey?auth_key=',
  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: 'PATCH',
  url: '{{baseUrl}}/authentication/authkey',
  qs: {auth_key: ''}
};

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

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

const req = unirest('PATCH', '{{baseUrl}}/authentication/authkey');

req.query({
  auth_key: ''
});

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

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/authentication/authkey',
  params: {auth_key: ''}
};

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

const url = '{{baseUrl}}/authentication/authkey?auth_key=';
const options = {method: 'PATCH'};

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}}/authentication/authkey?auth_key="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PATCH"];

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

let uri = Uri.of_string "{{baseUrl}}/authentication/authkey?auth_key=" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PATCH', '{{baseUrl}}/authentication/authkey?auth_key=');

echo $response->getBody();
setUrl('{{baseUrl}}/authentication/authkey');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

$request->setQueryData([
  'auth_key' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/authentication/authkey');
$request->setRequestMethod('PATCH');
$request->setQuery(new http\QueryString([
  'auth_key' => ''
]));

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

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/authentication/authkey?auth_key=' -Method PATCH 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/authentication/authkey?auth_key=' -Method PATCH 
import http.client

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

conn.request("PATCH", "/baseUrl/authentication/authkey?auth_key=")

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

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

url = "{{baseUrl}}/authentication/authkey"

querystring = {"auth_key":""}

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

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

url <- "{{baseUrl}}/authentication/authkey"

queryString <- list(auth_key = "")

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

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

url = URI("{{baseUrl}}/authentication/authkey?auth_key=")

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

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

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

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

response = conn.patch('/baseUrl/authentication/authkey') do |req|
  req.params['auth_key'] = ''
end

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

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

    let querystring = [
        ("auth_key", ""),
    ];

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

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

    dbg!(results);
}
curl --request PATCH \
  --url '{{baseUrl}}/authentication/authkey?auth_key='
http PATCH '{{baseUrl}}/authentication/authkey?auth_key='
wget --quiet \
  --method PATCH \
  --output-document \
  - '{{baseUrl}}/authentication/authkey?auth_key='
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/authentication/authkey?auth_key=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PATCH"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as 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 Deactivate app key (PUT)
{{baseUrl}}/authentication/appkey
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

app_key
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/authentication/appkey?app_key=");

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

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

(client/put "{{baseUrl}}/authentication/appkey" {:headers {:x-auth "{{apiKey}}"}
                                                                 :query-params {:app_key ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/authentication/appkey?app_key="

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

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

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

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

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

}
PUT /baseUrl/authentication/appkey?app_key= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/authentication/appkey?app_key=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/authentication/appkey?app_key=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/authentication/appkey',
  params: {app_key: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/authentication/appkey?app_key=';
const options = {method: 'PUT', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/authentication/appkey?app_key=',
  method: 'PUT',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/authentication/appkey?app_key=")
  .put(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/authentication/appkey?app_key=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

  res.on('data', function (chunk) {
    chunks.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}}/authentication/appkey',
  qs: {app_key: ''},
  headers: {'x-auth': '{{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}}/authentication/appkey');

req.query({
  app_key: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/authentication/appkey',
  params: {app_key: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/authentication/appkey?app_key=';
const options = {method: 'PUT', headers: {'x-auth': '{{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": @"{{apiKey}}" };

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

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/authentication/appkey?app_key=",
  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: {{apiKey}}"
  ],
]);

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

curl_close($curl);

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

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

$request->setQueryData([
  'app_key' => ''
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/authentication/appkey');
$request->setRequestMethod('PUT');
$request->setQuery(new http\QueryString([
  'app_key' => ''
]));

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

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

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

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

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

conn.request("PUT", "/baseUrl/authentication/appkey?app_key=", headers=headers)

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

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

url = "{{baseUrl}}/authentication/appkey"

querystring = {"app_key":""}

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

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

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

url <- "{{baseUrl}}/authentication/appkey"

queryString <- list(app_key = "")

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

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

url = URI("{{baseUrl}}/authentication/appkey?app_key=")

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

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

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

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

response = conn.put('/baseUrl/authentication/appkey') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['app_key'] = ''
end

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

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

    let querystring = [
        ("app_key", ""),
    ];

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

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

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

    dbg!(results);
}
curl --request PUT \
  --url '{{baseUrl}}/authentication/appkey?app_key=' \
  --header 'x-auth: {{apiKey}}'
http PUT '{{baseUrl}}/authentication/appkey?app_key=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/authentication/appkey?app_key='
import Foundation

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/authentication/appkey?app_key=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "success": true
}
PUT Deactivate app key
{{baseUrl}}/appkey
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

app_key
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/appkey?app_key=");

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

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

(client/put "{{baseUrl}}/appkey" {:headers {:x-auth "{{apiKey}}"}
                                                  :query-params {:app_key ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/appkey?app_key="

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

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

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

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

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

}
PUT /baseUrl/appkey?app_key= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/appkey?app_key=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/appkey?app_key=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/appkey',
  params: {app_key: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/appkey?app_key=';
const options = {method: 'PUT', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/appkey?app_key=',
  method: 'PUT',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/appkey?app_key=")
  .put(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/appkey?app_key=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

  res.on('data', function (chunk) {
    chunks.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}}/appkey',
  qs: {app_key: ''},
  headers: {'x-auth': '{{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}}/appkey');

req.query({
  app_key: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/appkey',
  params: {app_key: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/appkey?app_key=';
const options = {method: 'PUT', headers: {'x-auth': '{{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": @"{{apiKey}}" };

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

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/appkey?app_key=",
  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: {{apiKey}}"
  ],
]);

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

curl_close($curl);

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

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

$request->setQueryData([
  'app_key' => ''
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/appkey');
$request->setRequestMethod('PUT');
$request->setQuery(new http\QueryString([
  'app_key' => ''
]));

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

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

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

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

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

conn.request("PUT", "/baseUrl/appkey?app_key=", headers=headers)

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

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

url = "{{baseUrl}}/appkey"

querystring = {"app_key":""}

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

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

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

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

queryString <- list(app_key = "")

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

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

url = URI("{{baseUrl}}/appkey?app_key=")

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

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

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

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

response = conn.put('/baseUrl/appkey') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['app_key'] = ''
end

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

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

    let querystring = [
        ("app_key", ""),
    ];

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

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

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

    dbg!(results);
}
curl --request PUT \
  --url '{{baseUrl}}/appkey?app_key=' \
  --header 'x-auth: {{apiKey}}'
http PUT '{{baseUrl}}/appkey?app_key=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/appkey?app_key='
import Foundation

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/appkey?app_key=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "success": true
}
PUT Deactivate auth key (logout) (PUT)
{{baseUrl}}/authkey
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

auth_key
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/authkey?auth_key=");

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

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

(client/put "{{baseUrl}}/authkey" {:headers {:x-auth "{{apiKey}}"}
                                                   :query-params {:auth_key ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/authkey?auth_key="

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

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

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

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

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

}
PUT /baseUrl/authkey?auth_key= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/authkey?auth_key=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/authkey?auth_key=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/authkey',
  params: {auth_key: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/authkey?auth_key=';
const options = {method: 'PUT', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/authkey?auth_key=',
  method: 'PUT',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/authkey?auth_key=")
  .put(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/authkey?auth_key=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

  res.on('data', function (chunk) {
    chunks.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}}/authkey',
  qs: {auth_key: ''},
  headers: {'x-auth': '{{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}}/authkey');

req.query({
  auth_key: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/authkey',
  params: {auth_key: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/authkey?auth_key=';
const options = {method: 'PUT', headers: {'x-auth': '{{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": @"{{apiKey}}" };

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

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/authkey?auth_key=",
  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: {{apiKey}}"
  ],
]);

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

curl_close($curl);

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

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

$request->setQueryData([
  'auth_key' => ''
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/authkey');
$request->setRequestMethod('PUT');
$request->setQuery(new http\QueryString([
  'auth_key' => ''
]));

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

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

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

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

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

conn.request("PUT", "/baseUrl/authkey?auth_key=", headers=headers)

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

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

url = "{{baseUrl}}/authkey"

querystring = {"auth_key":""}

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

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

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

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

queryString <- list(auth_key = "")

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

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

url = URI("{{baseUrl}}/authkey?auth_key=")

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

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

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

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

response = conn.put('/baseUrl/authkey') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['auth_key'] = ''
end

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

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

    let querystring = [
        ("auth_key", ""),
    ];

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

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

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

    dbg!(results);
}
curl --request PUT \
  --url '{{baseUrl}}/authkey?auth_key=' \
  --header 'x-auth: {{apiKey}}'
http PUT '{{baseUrl}}/authkey?auth_key=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/authkey?auth_key='
import Foundation

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/authkey?auth_key=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "success": true
}
PUT Deactivate auth key (logout)
{{baseUrl}}/authentication/authkey
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

auth_key
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/authentication/authkey?auth_key=");

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

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

(client/put "{{baseUrl}}/authentication/authkey" {:headers {:x-auth "{{apiKey}}"}
                                                                  :query-params {:auth_key ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/authentication/authkey?auth_key="

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

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

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

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

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

}
PUT /baseUrl/authentication/authkey?auth_key= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/authentication/authkey?auth_key=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/authentication/authkey?auth_key=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/authentication/authkey',
  params: {auth_key: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/authentication/authkey?auth_key=';
const options = {method: 'PUT', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/authentication/authkey?auth_key=',
  method: 'PUT',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/authentication/authkey?auth_key=")
  .put(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/authentication/authkey?auth_key=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

  res.on('data', function (chunk) {
    chunks.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}}/authentication/authkey',
  qs: {auth_key: ''},
  headers: {'x-auth': '{{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}}/authentication/authkey');

req.query({
  auth_key: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/authentication/authkey',
  params: {auth_key: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/authentication/authkey?auth_key=';
const options = {method: 'PUT', headers: {'x-auth': '{{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": @"{{apiKey}}" };

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

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/authentication/authkey?auth_key=",
  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: {{apiKey}}"
  ],
]);

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

curl_close($curl);

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

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

$request->setQueryData([
  'auth_key' => ''
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/authentication/authkey');
$request->setRequestMethod('PUT');
$request->setQuery(new http\QueryString([
  'auth_key' => ''
]));

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

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

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

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

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

conn.request("PUT", "/baseUrl/authentication/authkey?auth_key=", headers=headers)

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

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

url = "{{baseUrl}}/authentication/authkey"

querystring = {"auth_key":""}

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

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

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

url <- "{{baseUrl}}/authentication/authkey"

queryString <- list(auth_key = "")

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

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

url = URI("{{baseUrl}}/authentication/authkey?auth_key=")

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

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

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

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

response = conn.put('/baseUrl/authentication/authkey') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['auth_key'] = ''
end

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

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

    let querystring = [
        ("auth_key", ""),
    ];

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

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

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

    dbg!(results);
}
curl --request PUT \
  --url '{{baseUrl}}/authentication/authkey?auth_key=' \
  --header 'x-auth: {{apiKey}}'
http PUT '{{baseUrl}}/authentication/authkey?auth_key=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/authentication/authkey?auth_key='
import Foundation

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/authentication/authkey?auth_key=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "success": true
}
POST Request app key (POST)
{{baseUrl}}/authentication/appkey
QUERY PARAMS

username
password
supportsYubikey
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey=");

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

(client/post "{{baseUrl}}/authentication/appkey" {:query-params {:username ""
                                                                                 :password ""
                                                                                 :supportsYubikey ""}})
require "http/client"

url = "{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey="

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}}/authentication/appkey?username=&password=&supportsYubikey="),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey=");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey="

	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/authentication/appkey?username=&password=&supportsYubikey= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey="))
    .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}}/authentication/appkey?username=&password=&supportsYubikey=")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey=")
  .asString();
const 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}}/authentication/appkey?username=&password=&supportsYubikey=');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/authentication/appkey',
  params: {username: '', password: '', supportsYubikey: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey=';
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}}/authentication/appkey?username=&password=&supportsYubikey=',
  method: 'POST',
  headers: {}
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey=")
  .post(null)
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/authentication/appkey?username=&password=&supportsYubikey=',
  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}}/authentication/appkey',
  qs: {username: '', password: '', supportsYubikey: ''}
};

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

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

const req = unirest('POST', '{{baseUrl}}/authentication/appkey');

req.query({
  username: '',
  password: '',
  supportsYubikey: ''
});

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}}/authentication/appkey',
  params: {username: '', password: '', supportsYubikey: ''}
};

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

const url = '{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey=';
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}}/authentication/appkey?username=&password=&supportsYubikey="]
                                                       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}}/authentication/appkey?username=&password=&supportsYubikey=" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey=",
  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}}/authentication/appkey?username=&password=&supportsYubikey=');

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

$request->setQueryData([
  'username' => '',
  'password' => '',
  'supportsYubikey' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/authentication/appkey');
$request->setRequestMethod('POST');
$request->setQuery(new http\QueryString([
  'username' => '',
  'password' => '',
  'supportsYubikey' => ''
]));

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

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey=' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey=' -Method POST 
import http.client

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

conn.request("POST", "/baseUrl/authentication/appkey?username=&password=&supportsYubikey=")

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

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

url = "{{baseUrl}}/authentication/appkey"

querystring = {"username":"","password":"","supportsYubikey":""}

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

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

url <- "{{baseUrl}}/authentication/appkey"

queryString <- list(
  username = "",
  password = "",
  supportsYubikey = ""
)

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

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

url = URI("{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey=")

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/authentication/appkey') do |req|
  req.params['username'] = ''
  req.params['password'] = ''
  req.params['supportsYubikey'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let querystring = [
        ("username", ""),
        ("password", ""),
        ("supportsYubikey", ""),
    ];

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

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

    dbg!(results);
}
curl --request POST \
  --url '{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey='
http POST '{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey='
wget --quiet \
  --method POST \
  --output-document \
  - '{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey='
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/authentication/appkey?username=&password=&supportsYubikey=")! 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()
POST Request app key
{{baseUrl}}/appkey
QUERY PARAMS

username
password
supportsYubikey
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/appkey?username=&password=&supportsYubikey=");

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

(client/post "{{baseUrl}}/appkey" {:query-params {:username ""
                                                                  :password ""
                                                                  :supportsYubikey ""}})
require "http/client"

url = "{{baseUrl}}/appkey?username=&password=&supportsYubikey="

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

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

func main() {

	url := "{{baseUrl}}/appkey?username=&password=&supportsYubikey="

	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/appkey?username=&password=&supportsYubikey= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/appkey?username=&password=&supportsYubikey=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/appkey?username=&password=&supportsYubikey="))
    .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}}/appkey?username=&password=&supportsYubikey=")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/appkey?username=&password=&supportsYubikey=")
  .asString();
const 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}}/appkey?username=&password=&supportsYubikey=');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/appkey',
  params: {username: '', password: '', supportsYubikey: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/appkey?username=&password=&supportsYubikey=';
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}}/appkey?username=&password=&supportsYubikey=',
  method: 'POST',
  headers: {}
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/appkey?username=&password=&supportsYubikey=")
  .post(null)
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/appkey?username=&password=&supportsYubikey=',
  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}}/appkey',
  qs: {username: '', password: '', supportsYubikey: ''}
};

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

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

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

req.query({
  username: '',
  password: '',
  supportsYubikey: ''
});

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}}/appkey',
  params: {username: '', password: '', supportsYubikey: ''}
};

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

const url = '{{baseUrl}}/appkey?username=&password=&supportsYubikey=';
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}}/appkey?username=&password=&supportsYubikey="]
                                                       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}}/appkey?username=&password=&supportsYubikey=" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/appkey?username=&password=&supportsYubikey=",
  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}}/appkey?username=&password=&supportsYubikey=');

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

$request->setQueryData([
  'username' => '',
  'password' => '',
  'supportsYubikey' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/appkey');
$request->setRequestMethod('POST');
$request->setQuery(new http\QueryString([
  'username' => '',
  'password' => '',
  'supportsYubikey' => ''
]));

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

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/appkey?username=&password=&supportsYubikey=' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/appkey?username=&password=&supportsYubikey=' -Method POST 
import http.client

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

conn.request("POST", "/baseUrl/appkey?username=&password=&supportsYubikey=")

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

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

url = "{{baseUrl}}/appkey"

querystring = {"username":"","password":"","supportsYubikey":""}

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

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

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

queryString <- list(
  username = "",
  password = "",
  supportsYubikey = ""
)

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

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

url = URI("{{baseUrl}}/appkey?username=&password=&supportsYubikey=")

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/appkey') do |req|
  req.params['username'] = ''
  req.params['password'] = ''
  req.params['supportsYubikey'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let querystring = [
        ("username", ""),
        ("password", ""),
        ("supportsYubikey", ""),
    ];

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

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

    dbg!(results);
}
curl --request POST \
  --url '{{baseUrl}}/appkey?username=&password=&supportsYubikey='
http POST '{{baseUrl}}/appkey?username=&password=&supportsYubikey='
wget --quiet \
  --method POST \
  --output-document \
  - '{{baseUrl}}/appkey?username=&password=&supportsYubikey='
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/appkey?username=&password=&supportsYubikey=")! 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()
POST Request auth key for user (login user) (1)
{{baseUrl}}/authkey
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

username
password
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/authkey?username=&password=");

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

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

(client/post "{{baseUrl}}/authkey" {:headers {:x-auth "{{apiKey}}"}
                                                    :query-params {:username ""
                                                                   :password ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/authkey?username=&password="

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

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

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

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

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

}
POST /baseUrl/authkey?username=&password= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/authkey?username=&password=")
  .setHeader("x-auth", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/authkey?username=&password="))
    .header("x-auth", "{{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}}/authkey?username=&password=")
  .post(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/authkey?username=&password=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/authkey?username=&password=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/authkey',
  params: {username: '', password: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/authkey?username=&password=';
const options = {method: 'POST', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/authkey?username=&password=',
  method: 'POST',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/authkey?username=&password=")
  .post(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/authkey?username=&password=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

  res.on('data', function (chunk) {
    chunks.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}}/authkey',
  qs: {username: '', password: ''},
  headers: {'x-auth': '{{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}}/authkey');

req.query({
  username: '',
  password: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/authkey',
  params: {username: '', password: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/authkey?username=&password=';
const options = {method: 'POST', headers: {'x-auth': '{{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": @"{{apiKey}}" };

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

Client.call ~headers `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/authkey?username=&password=",
  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: {{apiKey}}"
  ],
]);

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

curl_close($curl);

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

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

$request->setQueryData([
  'username' => '',
  'password' => ''
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/authkey');
$request->setRequestMethod('POST');
$request->setQuery(new http\QueryString([
  'username' => '',
  'password' => ''
]));

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

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

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

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

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

conn.request("POST", "/baseUrl/authkey?username=&password=", headers=headers)

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

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

url = "{{baseUrl}}/authkey"

querystring = {"username":"","password":""}

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

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

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

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

queryString <- list(
  username = "",
  password = ""
)

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

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

url = URI("{{baseUrl}}/authkey?username=&password=")

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

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

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

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

response = conn.post('/baseUrl/authkey') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['username'] = ''
  req.params['password'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let querystring = [
        ("username", ""),
        ("password", ""),
    ];

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

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

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

    dbg!(results);
}
curl --request POST \
  --url '{{baseUrl}}/authkey?username=&password=' \
  --header 'x-auth: {{apiKey}}'
http POST '{{baseUrl}}/authkey?username=&password=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/authkey?username=&password='
import Foundation

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/authkey?username=&password=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "auth_key": "8ou7jyubj878h7iunk",
  "success": true
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "Access Denied",
  "success": false
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "message": "OTP Required is configured for this User. Retry login with OTP",
  "success": false
}
GET Request auth key for user (login user) (GET)
{{baseUrl}}/authkey
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

username
password
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/authkey?username=&password=");

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

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

(client/get "{{baseUrl}}/authkey" {:headers {:x-auth "{{apiKey}}"}
                                                   :query-params {:username ""
                                                                  :password ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/authkey?username=&password="

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

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

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

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

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

}
GET /baseUrl/authkey?username=&password= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/authkey?username=&password=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/authkey?username=&password=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/authkey',
  params: {username: '', password: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/authkey?username=&password=';
const options = {method: 'GET', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/authkey?username=&password=',
  method: 'GET',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/authkey?username=&password=")
  .get()
  .addHeader("x-auth", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/authkey?username=&password=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

  res.on('data', function (chunk) {
    chunks.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}}/authkey',
  qs: {username: '', password: ''},
  headers: {'x-auth': '{{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}}/authkey');

req.query({
  username: '',
  password: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/authkey',
  params: {username: '', password: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/authkey?username=&password=';
const options = {method: 'GET', headers: {'x-auth': '{{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": @"{{apiKey}}" };

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

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/authkey?username=&password=",
  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: {{apiKey}}"
  ],
]);

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

curl_close($curl);

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

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

$request->setQueryData([
  'username' => '',
  'password' => ''
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/authkey');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'username' => '',
  'password' => ''
]));

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

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

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

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

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

conn.request("GET", "/baseUrl/authkey?username=&password=", headers=headers)

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

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

url = "{{baseUrl}}/authkey"

querystring = {"username":"","password":""}

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

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

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

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

queryString <- list(
  username = "",
  password = ""
)

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

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

url = URI("{{baseUrl}}/authkey?username=&password=")

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

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

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

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

response = conn.get('/baseUrl/authkey') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['username'] = ''
  req.params['password'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let querystring = [
        ("username", ""),
        ("password", ""),
    ];

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/authkey?username=&password=")! 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

{
  "auth_key": "8ou7jyubj878h7iunk",
  "success": true
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "Access Denied",
  "success": false
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "message": "OTP Required is configured for this User. Retry login with OTP",
  "success": false
}
POST Request auth key for user (login user) (POST)
{{baseUrl}}/authentication/authkey
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

username
password
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/authentication/authkey?username=&password=");

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

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

(client/post "{{baseUrl}}/authentication/authkey" {:headers {:x-auth "{{apiKey}}"}
                                                                   :query-params {:username ""
                                                                                  :password ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/authentication/authkey?username=&password="

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

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

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

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

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

}
POST /baseUrl/authentication/authkey?username=&password= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/authentication/authkey?username=&password=")
  .setHeader("x-auth", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/authentication/authkey?username=&password="))
    .header("x-auth", "{{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}}/authentication/authkey?username=&password=")
  .post(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/authentication/authkey?username=&password=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/authentication/authkey?username=&password=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/authentication/authkey',
  params: {username: '', password: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/authentication/authkey?username=&password=';
const options = {method: 'POST', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/authentication/authkey?username=&password=',
  method: 'POST',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/authentication/authkey?username=&password=")
  .post(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/authentication/authkey?username=&password=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

  res.on('data', function (chunk) {
    chunks.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}}/authentication/authkey',
  qs: {username: '', password: ''},
  headers: {'x-auth': '{{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}}/authentication/authkey');

req.query({
  username: '',
  password: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/authentication/authkey',
  params: {username: '', password: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/authentication/authkey?username=&password=';
const options = {method: 'POST', headers: {'x-auth': '{{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": @"{{apiKey}}" };

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

Client.call ~headers `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/authentication/authkey?username=&password=",
  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: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/authentication/authkey?username=&password=', [
  'headers' => [
    'x-auth' => '{{apiKey}}',
  ],
]);

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

$request->setQueryData([
  'username' => '',
  'password' => ''
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/authentication/authkey');
$request->setRequestMethod('POST');
$request->setQuery(new http\QueryString([
  'username' => '',
  'password' => ''
]));

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/authentication/authkey?username=&password=' -Method POST -Headers $headers
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/authentication/authkey?username=&password=' -Method POST -Headers $headers
import http.client

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

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

conn.request("POST", "/baseUrl/authentication/authkey?username=&password=", headers=headers)

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

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

url = "{{baseUrl}}/authentication/authkey"

querystring = {"username":"","password":""}

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

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

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

url <- "{{baseUrl}}/authentication/authkey"

queryString <- list(
  username = "",
  password = ""
)

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

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

url = URI("{{baseUrl}}/authentication/authkey?username=&password=")

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

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

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

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

response = conn.post('/baseUrl/authentication/authkey') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['username'] = ''
  req.params['password'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let querystring = [
        ("username", ""),
        ("password", ""),
    ];

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

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

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

    dbg!(results);
}
curl --request POST \
  --url '{{baseUrl}}/authentication/authkey?username=&password=' \
  --header 'x-auth: {{apiKey}}'
http POST '{{baseUrl}}/authentication/authkey?username=&password=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/authentication/authkey?username=&password='
import Foundation

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/authentication/authkey?username=&password=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "auth_key": "8ou7jyubj878h7iunk",
  "success": true
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "Access Denied",
  "success": false
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "message": "OTP Required is configured for this User. Retry login with OTP",
  "success": false
}
GET Request auth key for user (login user)
{{baseUrl}}/authentication/authkey
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

username
password
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/authentication/authkey?username=&password=");

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

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

(client/get "{{baseUrl}}/authentication/authkey" {:headers {:x-auth "{{apiKey}}"}
                                                                  :query-params {:username ""
                                                                                 :password ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/authentication/authkey?username=&password="

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

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

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

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

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

}
GET /baseUrl/authentication/authkey?username=&password= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/authentication/authkey?username=&password=")
  .setHeader("x-auth", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/authentication/authkey?username=&password=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/authentication/authkey?username=&password=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/authentication/authkey',
  params: {username: '', password: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/authentication/authkey?username=&password=';
const options = {method: 'GET', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/authentication/authkey?username=&password=',
  method: 'GET',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/authentication/authkey?username=&password=")
  .get()
  .addHeader("x-auth", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/authentication/authkey?username=&password=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

  res.on('data', function (chunk) {
    chunks.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}}/authentication/authkey',
  qs: {username: '', password: ''},
  headers: {'x-auth': '{{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}}/authentication/authkey');

req.query({
  username: '',
  password: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/authentication/authkey',
  params: {username: '', password: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/authentication/authkey?username=&password=';
const options = {method: 'GET', headers: {'x-auth': '{{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": @"{{apiKey}}" };

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

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/authentication/authkey?username=&password=",
  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: {{apiKey}}"
  ],
]);

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

curl_close($curl);

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

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

$request->setQueryData([
  'username' => '',
  'password' => ''
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/authentication/authkey');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'username' => '',
  'password' => ''
]));

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

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

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

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

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

conn.request("GET", "/baseUrl/authentication/authkey?username=&password=", headers=headers)

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

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

url = "{{baseUrl}}/authentication/authkey"

querystring = {"username":"","password":""}

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

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

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

url <- "{{baseUrl}}/authentication/authkey"

queryString <- list(
  username = "",
  password = ""
)

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

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

url = URI("{{baseUrl}}/authentication/authkey?username=&password=")

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

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

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

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

response = conn.get('/baseUrl/authentication/authkey') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['username'] = ''
  req.params['password'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let querystring = [
        ("username", ""),
        ("password", ""),
    ];

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/authentication/authkey?username=&password=")! 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

{
  "auth_key": "8ou7jyubj878h7iunk",
  "success": true
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "Access Denied",
  "success": false
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "message": "OTP Required is configured for this User. Retry login with OTP",
  "success": false
}
GET Verifies YubiKey OTP for authenticated user
{{baseUrl}}/authentication/verifyotp
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

otp
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/authentication/verifyotp?otp=");

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

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

(client/get "{{baseUrl}}/authentication/verifyotp" {:headers {:x-auth "{{apiKey}}"}
                                                                    :query-params {:otp ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/authentication/verifyotp?otp="

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

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

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

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

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

}
GET /baseUrl/authentication/verifyotp?otp= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/authentication/verifyotp',
  params: {otp: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/authentication/verifyotp?otp=';
const options = {method: 'GET', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/authentication/verifyotp?otp=',
  method: 'GET',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/authentication/verifyotp?otp=")
  .get()
  .addHeader("x-auth", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/authentication/verifyotp?otp=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

  res.on('data', function (chunk) {
    chunks.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}}/authentication/verifyotp',
  qs: {otp: ''},
  headers: {'x-auth': '{{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}}/authentication/verifyotp');

req.query({
  otp: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/authentication/verifyotp',
  params: {otp: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/authentication/verifyotp?otp=';
const options = {method: 'GET', headers: {'x-auth': '{{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": @"{{apiKey}}" };

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

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/authentication/verifyotp?otp=",
  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: {{apiKey}}"
  ],
]);

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

curl_close($curl);

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

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

$request->setQueryData([
  'otp' => ''
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/authentication/verifyotp');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'otp' => ''
]));

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

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

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

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

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

conn.request("GET", "/baseUrl/authentication/verifyotp?otp=", headers=headers)

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

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

url = "{{baseUrl}}/authentication/verifyotp"

querystring = {"otp":""}

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

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

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

url <- "{{baseUrl}}/authentication/verifyotp"

queryString <- list(otp = "")

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

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

url = URI("{{baseUrl}}/authentication/verifyotp?otp=")

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

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

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

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

response = conn.get('/baseUrl/authentication/verifyotp') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['otp'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let querystring = [
        ("otp", ""),
    ];

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/authentication/verifyotp?otp=")! 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

{
  "error": "Access Denied",
  "success": false
}
POST Add item to kid's wishlist
{{baseUrl}}/kkid/wishlist
QUERY PARAMS

kidUserId
title
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/wishlist?kidUserId=&title=");

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

(client/post "{{baseUrl}}/kkid/wishlist" {:query-params {:kidUserId ""
                                                                         :title ""}})
require "http/client"

url = "{{baseUrl}}/kkid/wishlist?kidUserId=&title="

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

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

func main() {

	url := "{{baseUrl}}/kkid/wishlist?kidUserId=&title="

	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/kkid/wishlist?kidUserId=&title= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/kkid/wishlist?kidUserId=&title=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/wishlist?kidUserId=&title="))
    .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}}/kkid/wishlist?kidUserId=&title=")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/kkid/wishlist?kidUserId=&title=")
  .asString();
const 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}}/kkid/wishlist?kidUserId=&title=');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/kkid/wishlist',
  params: {kidUserId: '', title: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/kkid/wishlist?kidUserId=&title=';
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}}/kkid/wishlist?kidUserId=&title=',
  method: 'POST',
  headers: {}
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/wishlist?kidUserId=&title=")
  .post(null)
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/wishlist?kidUserId=&title=',
  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}}/kkid/wishlist',
  qs: {kidUserId: '', title: ''}
};

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

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

const req = unirest('POST', '{{baseUrl}}/kkid/wishlist');

req.query({
  kidUserId: '',
  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}}/kkid/wishlist',
  params: {kidUserId: '', title: ''}
};

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

const url = '{{baseUrl}}/kkid/wishlist?kidUserId=&title=';
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}}/kkid/wishlist?kidUserId=&title="]
                                                       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}}/kkid/wishlist?kidUserId=&title=" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/kkid/wishlist?kidUserId=&title=",
  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}}/kkid/wishlist?kidUserId=&title=');

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

$request->setQueryData([
  'kidUserId' => '',
  'title' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/wishlist');
$request->setRequestMethod('POST');
$request->setQuery(new http\QueryString([
  'kidUserId' => '',
  'title' => ''
]));

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

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/wishlist?kidUserId=&title=' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/wishlist?kidUserId=&title=' -Method POST 
import http.client

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

conn.request("POST", "/baseUrl/kkid/wishlist?kidUserId=&title=")

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

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

url = "{{baseUrl}}/kkid/wishlist"

querystring = {"kidUserId":"","title":""}

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

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

url <- "{{baseUrl}}/kkid/wishlist"

queryString <- list(
  kidUserId = "",
  title = ""
)

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

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

url = URI("{{baseUrl}}/kkid/wishlist?kidUserId=&title=")

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/kkid/wishlist') do |req|
  req.params['kidUserId'] = ''
  req.params['title'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let querystring = [
        ("kidUserId", ""),
        ("title", ""),
    ];

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

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

    dbg!(results);
}
curl --request POST \
  --url '{{baseUrl}}/kkid/wishlist?kidUserId=&title='
http POST '{{baseUrl}}/kkid/wishlist?kidUserId=&title='
wget --quiet \
  --method POST \
  --output-document \
  - '{{baseUrl}}/kkid/wishlist?kidUserId=&title='
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/wishlist?kidUserId=&title=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "message": "success",
  "success": true
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/share?linkUserId=&link=&scope=");

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

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

(client/get "{{baseUrl}}/kkid/share" {:headers {:x-auth "{{apiKey}}"}
                                                      :query-params {:linkUserId ""
                                                                     :link ""
                                                                     :scope ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/kkid/share?linkUserId=&link=&scope="

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

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

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

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

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

}
GET /baseUrl/kkid/share?linkUserId=&link=&scope= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/kkid/share?linkUserId=&link=&scope=")
  .setHeader("x-auth", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/share?linkUserId=&link=&scope="))
    .header("x-auth", "{{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}}/kkid/share?linkUserId=&link=&scope=")
  .get()
  .addHeader("x-auth", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/kkid/share?linkUserId=&link=&scope=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/kkid/share?linkUserId=&link=&scope=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/kkid/share',
  params: {linkUserId: '', link: '', scope: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/kkid/share?linkUserId=&link=&scope=';
const options = {method: 'GET', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/kkid/share?linkUserId=&link=&scope=',
  method: 'GET',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/share?linkUserId=&link=&scope=")
  .get()
  .addHeader("x-auth", "{{apiKey}}")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/share?linkUserId=&link=&scope=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

  res.on('data', function (chunk) {
    chunks.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}}/kkid/share',
  qs: {linkUserId: '', link: '', scope: ''},
  headers: {'x-auth': '{{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}}/kkid/share');

req.query({
  linkUserId: '',
  link: '',
  scope: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/kkid/share',
  params: {linkUserId: '', link: '', scope: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/kkid/share?linkUserId=&link=&scope=';
const options = {method: 'GET', headers: {'x-auth': '{{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": @"{{apiKey}}" };

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

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/kkid/share?linkUserId=&link=&scope=",
  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: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/kkid/share?linkUserId=&link=&scope=', [
  'headers' => [
    'x-auth' => '{{apiKey}}',
  ],
]);

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

$request->setQueryData([
  'linkUserId' => '',
  'link' => '',
  'scope' => ''
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/share');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'linkUserId' => '',
  'link' => '',
  'scope' => ''
]));

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/share?linkUserId=&link=&scope=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/share?linkUserId=&link=&scope=' -Method GET -Headers $headers
import http.client

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

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

conn.request("GET", "/baseUrl/kkid/share?linkUserId=&link=&scope=", headers=headers)

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

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

url = "{{baseUrl}}/kkid/share"

querystring = {"linkUserId":"","link":"","scope":""}

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

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

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

url <- "{{baseUrl}}/kkid/share"

queryString <- list(
  linkUserId = "",
  link = "",
  scope = ""
)

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

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

url = URI("{{baseUrl}}/kkid/share?linkUserId=&link=&scope=")

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

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

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

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

response = conn.get('/baseUrl/kkid/share') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['linkUserId'] = ''
  req.params['link'] = ''
  req.params['scope'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let querystring = [
        ("linkUserId", ""),
        ("link", ""),
        ("scope", ""),
    ];

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/share?linkUserId=&link=&scope=")! 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

{
  "auth_link": "https://khome.kumpeapps.com/portal/wish-list.php?token=8ou7jyubj878h7iunk",
  "success": true
}
DELETE Delete item from wishlist
{{baseUrl}}/kkid/wishlist
QUERY PARAMS

wishId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/wishlist?wishId=");

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

(client/delete "{{baseUrl}}/kkid/wishlist" {:query-params {:wishId ""}})
require "http/client"

url = "{{baseUrl}}/kkid/wishlist?wishId="

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

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

func main() {

	url := "{{baseUrl}}/kkid/wishlist?wishId="

	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/kkid/wishlist?wishId= HTTP/1.1
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/kkid/wishlist?wishId=")
  .asString();
const 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}}/kkid/wishlist?wishId=');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/kkid/wishlist',
  params: {wishId: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/wishlist?wishId=")
  .delete(null)
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/wishlist?wishId=',
  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}}/kkid/wishlist',
  qs: {wishId: ''}
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/kkid/wishlist');

req.query({
  wishId: ''
});

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}}/kkid/wishlist',
  params: {wishId: ''}
};

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

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

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

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

$request->setQueryData([
  'wishId' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/wishlist');
$request->setRequestMethod('DELETE');
$request->setQuery(new http\QueryString([
  'wishId' => ''
]));

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

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/wishlist?wishId=' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/wishlist?wishId=' -Method DELETE 
import http.client

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

conn.request("DELETE", "/baseUrl/kkid/wishlist?wishId=")

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

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

url = "{{baseUrl}}/kkid/wishlist"

querystring = {"wishId":""}

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

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

url <- "{{baseUrl}}/kkid/wishlist"

queryString <- list(wishId = "")

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

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

url = URI("{{baseUrl}}/kkid/wishlist?wishId=")

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/kkid/wishlist') do |req|
  req.params['wishId'] = ''
end

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

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

    let querystring = [
        ("wishId", ""),
    ];

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

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

    dbg!(results);
}
curl --request DELETE \
  --url '{{baseUrl}}/kkid/wishlist?wishId='
http DELETE '{{baseUrl}}/kkid/wishlist?wishId='
wget --quiet \
  --method DELETE \
  --output-document \
  - '{{baseUrl}}/kkid/wishlist?wishId='
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/wishlist?wishId=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "message": "success",
  "success": true
}
GET Get list of wishlist items
{{baseUrl}}/kkid/wishlist
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

(client/get "{{baseUrl}}/kkid/wishlist")
require "http/client"

url = "{{baseUrl}}/kkid/wishlist"

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

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

func main() {

	url := "{{baseUrl}}/kkid/wishlist"

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/kkid/wishlist")

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

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

url = "{{baseUrl}}/kkid/wishlist"

response = requests.get(url)

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

url <- "{{baseUrl}}/kkid/wishlist"

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

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

url = URI("{{baseUrl}}/kkid/wishlist")

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

puts response.status
puts response.body
use reqwest;

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

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

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

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

dataTask.resume()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "success": true,
  "wish": [
    {
      "description": "Pokemon trading cards",
      "id": 1,
      "link": "https://www.google.com",
      "master_id": 1,
      "priority": 1,
      "title": "Pokemon Cards",
      "user_id": 1
    },
    {
      "description": "Pokemon trading cards",
      "id": 1,
      "link": "https://www.google.com",
      "master_id": 1,
      "priority": 1,
      "title": "Pokemon Cards",
      "user_id": 1
    }
  ]
}
GET Gets user info
{{baseUrl}}/kkid/user
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

(client/get "{{baseUrl}}/kkid/user")
require "http/client"

url = "{{baseUrl}}/kkid/user"

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

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

func main() {

	url := "{{baseUrl}}/kkid/user"

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/kkid/user")

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

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

url = "{{baseUrl}}/kkid/user"

response = requests.get(url)

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

url <- "{{baseUrl}}/kkid/user"

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

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

url = URI("{{baseUrl}}/kkid/user")

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

puts response.status
puts response.body
use reqwest;

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

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

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

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

dataTask.resume()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "success": true,
  "user": [
    {
      "email": "jane@doe.com",
      "emoji": "🤗",
      "enableAllowance": true,
      "enableBehaviorChart": false,
      "enableChores": true,
      "enableNoAds": false,
      "enableObjectDetection": false,
      "enableTmdb": true,
      "firstName": "Jane",
      "homeId": 1,
      "isActive": true,
      "isAdmin": false,
      "isBanned": false,
      "isChild": true,
      "isDisabled": false,
      "isLocked": false,
      "isMaster": false,
      "lastName": "Doe",
      "masterId": 1,
      "pushAllowance": true,
      "pushAllowanceNew": true,
      "pushChores": true,
      "pushChoresNew": true,
      "pushChoresReminders": true,
      "tmdbKey": "9a87huiufe94r8",
      "userId": 10,
      "username": "janedoe",
      "weeklyAllowance": 5
    },
    {
      "email": "jane@doe.com",
      "emoji": "🤗",
      "enableAllowance": true,
      "enableBehaviorChart": false,
      "enableChores": true,
      "enableNoAds": false,
      "enableObjectDetection": false,
      "enableTmdb": true,
      "firstName": "Jane",
      "homeId": 1,
      "isActive": true,
      "isAdmin": false,
      "isBanned": false,
      "isChild": true,
      "isDisabled": false,
      "isLocked": false,
      "isMaster": false,
      "lastName": "Doe",
      "masterId": 1,
      "pushAllowance": true,
      "pushAllowanceNew": true,
      "pushChores": true,
      "pushChoresNew": true,
      "pushChoresReminders": true,
      "tmdbKey": "9a87huiufe94r8",
      "userId": 10,
      "username": "janedoe",
      "weeklyAllowance": 5
    }
  ]
}
PUT Update item on kid's wishlist
{{baseUrl}}/kkid/wishlist
QUERY PARAMS

wishId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/wishlist?wishId=");

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

(client/put "{{baseUrl}}/kkid/wishlist" {:query-params {:wishId ""}})
require "http/client"

url = "{{baseUrl}}/kkid/wishlist?wishId="

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

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

func main() {

	url := "{{baseUrl}}/kkid/wishlist?wishId="

	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/kkid/wishlist?wishId= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/kkid/wishlist?wishId=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/wishlist?wishId="))
    .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}}/kkid/wishlist?wishId=")
  .put(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/kkid/wishlist?wishId=")
  .asString();
const 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}}/kkid/wishlist?wishId=');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/kkid/wishlist',
  params: {wishId: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/wishlist?wishId=")
  .put(null)
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/wishlist?wishId=',
  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}}/kkid/wishlist',
  qs: {wishId: ''}
};

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

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

const req = unirest('PUT', '{{baseUrl}}/kkid/wishlist');

req.query({
  wishId: ''
});

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}}/kkid/wishlist',
  params: {wishId: ''}
};

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

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

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

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

$request->setQueryData([
  'wishId' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/wishlist');
$request->setRequestMethod('PUT');
$request->setQuery(new http\QueryString([
  'wishId' => ''
]));

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

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/wishlist?wishId=' -Method PUT 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/wishlist?wishId=' -Method PUT 
import http.client

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

conn.request("PUT", "/baseUrl/kkid/wishlist?wishId=")

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

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

url = "{{baseUrl}}/kkid/wishlist"

querystring = {"wishId":""}

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

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

url <- "{{baseUrl}}/kkid/wishlist"

queryString <- list(wishId = "")

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

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

url = URI("{{baseUrl}}/kkid/wishlist?wishId=")

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/kkid/wishlist') do |req|
  req.params['wishId'] = ''
end

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

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

    let querystring = [
        ("wishId", ""),
    ];

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

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

    dbg!(results);
}
curl --request PUT \
  --url '{{baseUrl}}/kkid/wishlist?wishId='
http PUT '{{baseUrl}}/kkid/wishlist?wishId='
wget --quiet \
  --method PUT \
  --output-document \
  - '{{baseUrl}}/kkid/wishlist?wishId='
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/wishlist?wishId=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "message": "success",
  "success": true
}
POST adds chore for given user
{{baseUrl}}/kkid/chorelist
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

kidUsername
choreName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=");

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

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

(client/post "{{baseUrl}}/kkid/chorelist" {:headers {:x-auth "{{apiKey}}"}
                                                           :query-params {:kidUsername ""
                                                                          :choreName ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/kkid/chorelist?kidUsername=&choreName="

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

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

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

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

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

}
POST /baseUrl/kkid/chorelist?kidUsername=&choreName= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=")
  .setHeader("x-auth", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/chorelist?kidUsername=&choreName="))
    .header("x-auth", "{{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}}/kkid/chorelist?kidUsername=&choreName=")
  .post(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/kkid/chorelist?kidUsername=&choreName=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/kkid/chorelist',
  params: {kidUsername: '', choreName: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=';
const options = {method: 'POST', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=',
  method: 'POST',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=")
  .post(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/chorelist?kidUsername=&choreName=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

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

  res.on('data', function (chunk) {
    chunks.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}}/kkid/chorelist',
  qs: {kidUsername: '', choreName: ''},
  headers: {'x-auth': '{{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}}/kkid/chorelist');

req.query({
  kidUsername: '',
  choreName: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/kkid/chorelist',
  params: {kidUsername: '', choreName: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

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

const url = '{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=';
const options = {method: 'POST', headers: {'x-auth': '{{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": @"{{apiKey}}" };

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

Client.call ~headers `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=",
  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: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=', [
  'headers' => [
    'x-auth' => '{{apiKey}}',
  ],
]);

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

$request->setQueryData([
  'kidUsername' => '',
  'choreName' => ''
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/chorelist');
$request->setRequestMethod('POST');
$request->setQuery(new http\QueryString([
  'kidUsername' => '',
  'choreName' => ''
]));

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

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=' -Method POST -Headers $headers
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=' -Method POST -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth': "{{apiKey}}" }

conn.request("POST", "/baseUrl/kkid/chorelist?kidUsername=&choreName=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/kkid/chorelist"

querystring = {"kidUsername":"","choreName":""}

headers = {"x-auth": "{{apiKey}}"}

response = requests.post(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/kkid/chorelist"

queryString <- list(
  kidUsername = "",
  choreName = ""
)

response <- VERB("POST", url, query = queryString, add_headers('x-auth' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/kkid/chorelist') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['kidUsername'] = ''
  req.params['choreName'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/kkid/chorelist";

    let querystring = [
        ("kidUsername", ""),
        ("choreName", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .query(&querystring)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url '{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=' \
  --header 'x-auth: {{apiKey}}'
http POST '{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/kkid/chorelist?kidUsername=&choreName='
import Foundation

let headers = ["x-auth": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/chorelist?kidUsername=&choreName=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "message": "success",
  "success": true
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "No Data Found",
  "status": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API account does not have access to this Verb Method!",
  "success": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API key is invalid or has expired!",
  "success": 0
}
POST adds new allowance transaction to kidUserID
{{baseUrl}}/kkid/allowance
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

kidUserId
amount
description
transactionType
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/kkid/allowance" {:headers {:x-auth "{{apiKey}}"}
                                                           :query-params {:kidUserId ""
                                                                          :amount ""
                                                                          :description ""
                                                                          :transactionType ""}})
require "http/client"

url = "{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType="
headers = HTTP::Headers{
  "x-auth" => "{{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}}/kkid/allowance?kidUserId=&amount=&description=&transactionType="),
    Headers =
    {
        { "x-auth", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType="

	req, _ := http.NewRequest("POST", url, nil)

	req.Header.Add("x-auth", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/kkid/allowance?kidUserId=&amount=&description=&transactionType= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=")
  .setHeader("x-auth", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType="))
    .header("x-auth", "{{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}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=")
  .post(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/kkid/allowance',
  params: {kidUserId: '', amount: '', description: '', transactionType: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=';
const options = {method: 'POST', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=',
  method: 'POST',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=")
  .post(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/allowance?kidUserId=&amount=&description=&transactionType=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/kkid/allowance',
  qs: {kidUserId: '', amount: '', description: '', transactionType: ''},
  headers: {'x-auth': '{{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}}/kkid/allowance');

req.query({
  kidUserId: '',
  amount: '',
  description: '',
  transactionType: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/kkid/allowance',
  params: {kidUserId: '', amount: '', description: '', transactionType: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=';
const options = {method: 'POST', headers: {'x-auth': '{{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": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType="]
                                                       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}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=" in
let headers = Header.add (Header.init ()) "x-auth" "{{apiKey}}" in

Client.call ~headers `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=",
  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: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=', [
  'headers' => [
    'x-auth' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/kkid/allowance');
$request->setMethod(HTTP_METH_POST);

$request->setQueryData([
  'kidUserId' => '',
  'amount' => '',
  'description' => '',
  'transactionType' => ''
]);

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/allowance');
$request->setRequestMethod('POST');
$request->setQuery(new http\QueryString([
  'kidUserId' => '',
  'amount' => '',
  'description' => '',
  'transactionType' => ''
]));

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=' -Method POST -Headers $headers
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=' -Method POST -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth': "{{apiKey}}" }

conn.request("POST", "/baseUrl/kkid/allowance?kidUserId=&amount=&description=&transactionType=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/kkid/allowance"

querystring = {"kidUserId":"","amount":"","description":"","transactionType":""}

headers = {"x-auth": "{{apiKey}}"}

response = requests.post(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/kkid/allowance"

queryString <- list(
  kidUserId = "",
  amount = "",
  description = "",
  transactionType = ""
)

response <- VERB("POST", url, query = queryString, add_headers('x-auth' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/kkid/allowance') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['kidUserId'] = ''
  req.params['amount'] = ''
  req.params['description'] = ''
  req.params['transactionType'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/kkid/allowance";

    let querystring = [
        ("kidUserId", ""),
        ("amount", ""),
        ("description", ""),
        ("transactionType", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .query(&querystring)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url '{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=' \
  --header 'x-auth: {{apiKey}}'
http POST '{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType='
import Foundation

let headers = ["x-auth": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/allowance?kidUserId=&amount=&description=&transactionType=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "message": "success",
  "success": true
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "No Data Found",
  "status": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API account does not have access to this Verb Method!",
  "success": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API key is invalid or has expired!",
  "success": 0
}
POST adds new child user
{{baseUrl}}/kkid/userlist
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

username
password
email
firstName
lastName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/kkid/userlist" {:headers {:x-auth "{{apiKey}}"}
                                                          :query-params {:username ""
                                                                         :password ""
                                                                         :email ""
                                                                         :firstName ""
                                                                         :lastName ""}})
require "http/client"

url = "{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName="
headers = HTTP::Headers{
  "x-auth" => "{{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}}/kkid/userlist?username=&password=&email=&firstName=&lastName="),
    Headers =
    {
        { "x-auth", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName="

	req, _ := http.NewRequest("POST", url, nil)

	req.Header.Add("x-auth", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/kkid/userlist?username=&password=&email=&firstName=&lastName= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=")
  .setHeader("x-auth", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName="))
    .header("x-auth", "{{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}}/kkid/userlist?username=&password=&email=&firstName=&lastName=")
  .post(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/kkid/userlist?username=&password=&email=&firstName=&lastName=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/kkid/userlist',
  params: {username: '', password: '', email: '', firstName: '', lastName: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=';
const options = {method: 'POST', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=',
  method: 'POST',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=")
  .post(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/userlist?username=&password=&email=&firstName=&lastName=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/kkid/userlist',
  qs: {username: '', password: '', email: '', firstName: '', lastName: ''},
  headers: {'x-auth': '{{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}}/kkid/userlist');

req.query({
  username: '',
  password: '',
  email: '',
  firstName: '',
  lastName: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/kkid/userlist',
  params: {username: '', password: '', email: '', firstName: '', lastName: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=';
const options = {method: 'POST', headers: {'x-auth': '{{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": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName="]
                                                       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}}/kkid/userlist?username=&password=&email=&firstName=&lastName=" in
let headers = Header.add (Header.init ()) "x-auth" "{{apiKey}}" in

Client.call ~headers `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=",
  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: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=', [
  'headers' => [
    'x-auth' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/kkid/userlist');
$request->setMethod(HTTP_METH_POST);

$request->setQueryData([
  'username' => '',
  'password' => '',
  'email' => '',
  'firstName' => '',
  'lastName' => ''
]);

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/userlist');
$request->setRequestMethod('POST');
$request->setQuery(new http\QueryString([
  'username' => '',
  'password' => '',
  'email' => '',
  'firstName' => '',
  'lastName' => ''
]));

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=' -Method POST -Headers $headers
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=' -Method POST -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth': "{{apiKey}}" }

conn.request("POST", "/baseUrl/kkid/userlist?username=&password=&email=&firstName=&lastName=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/kkid/userlist"

querystring = {"username":"","password":"","email":"","firstName":"","lastName":""}

headers = {"x-auth": "{{apiKey}}"}

response = requests.post(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/kkid/userlist"

queryString <- list(
  username = "",
  password = "",
  email = "",
  firstName = "",
  lastName = ""
)

response <- VERB("POST", url, query = queryString, add_headers('x-auth' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/kkid/userlist') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['username'] = ''
  req.params['password'] = ''
  req.params['email'] = ''
  req.params['firstName'] = ''
  req.params['lastName'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/kkid/userlist";

    let querystring = [
        ("username", ""),
        ("password", ""),
        ("email", ""),
        ("firstName", ""),
        ("lastName", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .query(&querystring)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url '{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=' \
  --header 'x-auth: {{apiKey}}'
http POST '{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName='
import Foundation

let headers = ["x-auth": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/userlist?username=&password=&email=&firstName=&lastName=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "added": {},
  "aff_added": "aff_added",
  "aff_id": "aff_id",
  "aff_payout_type": "aff_payout_type",
  "avatar": "avatar",
  "city": "city",
  "comment": "Added Via KKids API",
  "country": "country",
  "disable_lock_until": "disable_lock_until",
  "email": "jane@doe.com",
  "i_agree": "0",
  "is_affiliate": "is_affiliate",
  "is_locked": "0",
  "lang": "lang",
  "last_login": "last_login",
  "login": "janedoe",
  "name_f": "Jane",
  "name_l": "Doe",
  "pass": "pass",
  "pass_dattm": {},
  "phone": "phone",
  "pin": "0",
  "plain_password": "plain_password",
  "remember_key": "remember_key",
  "remote_addr": "104.237.5.109",
  "require_consent": "require_consent",
  "reseller_id": "reseller_id",
  "saved_form_id": "saved_form_id",
  "state": "state",
  "status": "0",
  "street": "street",
  "street2": "street2",
  "subusers_parent_id": "0",
  "tax_id": "tax_id",
  "unsubscribed": "0",
  "user_agent": "user_agent",
  "user_id": 1,
  "zip": "zip"
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API account does not have access to this Verb Method!",
  "success": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API key is invalid or has expired!",
  "success": 0
}
POST adds new master user account
{{baseUrl}}/kkid/masteruser
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

username
password
email
firstName
lastName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/kkid/masteruser" {:headers {:x-auth "{{apiKey}}"}
                                                            :query-params {:username ""
                                                                           :password ""
                                                                           :email ""
                                                                           :firstName ""
                                                                           :lastName ""}})
require "http/client"

url = "{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName="
headers = HTTP::Headers{
  "x-auth" => "{{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}}/kkid/masteruser?username=&password=&email=&firstName=&lastName="),
    Headers =
    {
        { "x-auth", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName="

	req, _ := http.NewRequest("POST", url, nil)

	req.Header.Add("x-auth", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/kkid/masteruser?username=&password=&email=&firstName=&lastName= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=")
  .setHeader("x-auth", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName="))
    .header("x-auth", "{{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}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=")
  .post(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/kkid/masteruser',
  params: {username: '', password: '', email: '', firstName: '', lastName: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=';
const options = {method: 'POST', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=',
  method: 'POST',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=")
  .post(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/masteruser?username=&password=&email=&firstName=&lastName=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/kkid/masteruser',
  qs: {username: '', password: '', email: '', firstName: '', lastName: ''},
  headers: {'x-auth': '{{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}}/kkid/masteruser');

req.query({
  username: '',
  password: '',
  email: '',
  firstName: '',
  lastName: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/kkid/masteruser',
  params: {username: '', password: '', email: '', firstName: '', lastName: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=';
const options = {method: 'POST', headers: {'x-auth': '{{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": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName="]
                                                       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}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=" in
let headers = Header.add (Header.init ()) "x-auth" "{{apiKey}}" in

Client.call ~headers `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=",
  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: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=', [
  'headers' => [
    'x-auth' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/kkid/masteruser');
$request->setMethod(HTTP_METH_POST);

$request->setQueryData([
  'username' => '',
  'password' => '',
  'email' => '',
  'firstName' => '',
  'lastName' => ''
]);

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/masteruser');
$request->setRequestMethod('POST');
$request->setQuery(new http\QueryString([
  'username' => '',
  'password' => '',
  'email' => '',
  'firstName' => '',
  'lastName' => ''
]));

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=' -Method POST -Headers $headers
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=' -Method POST -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth': "{{apiKey}}" }

conn.request("POST", "/baseUrl/kkid/masteruser?username=&password=&email=&firstName=&lastName=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/kkid/masteruser"

querystring = {"username":"","password":"","email":"","firstName":"","lastName":""}

headers = {"x-auth": "{{apiKey}}"}

response = requests.post(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/kkid/masteruser"

queryString <- list(
  username = "",
  password = "",
  email = "",
  firstName = "",
  lastName = ""
)

response <- VERB("POST", url, query = queryString, add_headers('x-auth' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/kkid/masteruser') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['username'] = ''
  req.params['password'] = ''
  req.params['email'] = ''
  req.params['firstName'] = ''
  req.params['lastName'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/kkid/masteruser";

    let querystring = [
        ("username", ""),
        ("password", ""),
        ("email", ""),
        ("firstName", ""),
        ("lastName", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .query(&querystring)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url '{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=' \
  --header 'x-auth: {{apiKey}}'
http POST '{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName='
import Foundation

let headers = ["x-auth": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/masteruser?username=&password=&email=&firstName=&lastName=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "added": {},
  "aff_added": "aff_added",
  "aff_id": "aff_id",
  "aff_payout_type": "aff_payout_type",
  "avatar": "avatar",
  "city": "city",
  "comment": "Added Via KKids API",
  "country": "country",
  "disable_lock_until": "disable_lock_until",
  "email": "jane@doe.com",
  "i_agree": "0",
  "is_affiliate": "is_affiliate",
  "is_locked": "0",
  "lang": "lang",
  "last_login": "last_login",
  "login": "janedoe",
  "name_f": "Jane",
  "name_l": "Doe",
  "pass": "pass",
  "pass_dattm": {},
  "phone": "phone",
  "pin": "0",
  "plain_password": "plain_password",
  "remember_key": "remember_key",
  "remote_addr": "104.237.5.109",
  "require_consent": "require_consent",
  "reseller_id": "reseller_id",
  "saved_form_id": "saved_form_id",
  "state": "state",
  "status": "0",
  "street": "street",
  "street2": "street2",
  "subusers_parent_id": "0",
  "tax_id": "tax_id",
  "unsubscribed": "0",
  "user_agent": "user_agent",
  "user_id": 1,
  "zip": "zip"
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API account does not have access to this Verb Method!",
  "success": 0
}
DELETE deletes chore for given chore id
{{baseUrl}}/kkid/chorelist
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

idChoreList
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/chorelist?idChoreList=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/kkid/chorelist" {:headers {:x-auth "{{apiKey}}"}
                                                             :query-params {:idChoreList ""}})
require "http/client"

url = "{{baseUrl}}/kkid/chorelist?idChoreList="
headers = HTTP::Headers{
  "x-auth" => "{{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}}/kkid/chorelist?idChoreList="),
    Headers =
    {
        { "x-auth", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/kkid/chorelist?idChoreList=");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/kkid/chorelist?idChoreList="

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/kkid/chorelist?idChoreList= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/kkid/chorelist?idChoreList=")
  .setHeader("x-auth", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/chorelist?idChoreList="))
    .header("x-auth", "{{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}}/kkid/chorelist?idChoreList=")
  .delete(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/kkid/chorelist?idChoreList=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/kkid/chorelist?idChoreList=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/kkid/chorelist',
  params: {idChoreList: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/kkid/chorelist?idChoreList=';
const options = {method: 'DELETE', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/kkid/chorelist?idChoreList=',
  method: 'DELETE',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/chorelist?idChoreList=")
  .delete(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/chorelist?idChoreList=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/kkid/chorelist',
  qs: {idChoreList: ''},
  headers: {'x-auth': '{{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}}/kkid/chorelist');

req.query({
  idChoreList: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/kkid/chorelist',
  params: {idChoreList: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/kkid/chorelist?idChoreList=';
const options = {method: 'DELETE', headers: {'x-auth': '{{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": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/kkid/chorelist?idChoreList="]
                                                       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}}/kkid/chorelist?idChoreList=" in
let headers = Header.add (Header.init ()) "x-auth" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/kkid/chorelist?idChoreList=",
  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: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/kkid/chorelist?idChoreList=', [
  'headers' => [
    'x-auth' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/kkid/chorelist');
$request->setMethod(HTTP_METH_DELETE);

$request->setQueryData([
  'idChoreList' => ''
]);

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/chorelist');
$request->setRequestMethod('DELETE');
$request->setQuery(new http\QueryString([
  'idChoreList' => ''
]));

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/chorelist?idChoreList=' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/chorelist?idChoreList=' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/kkid/chorelist?idChoreList=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/kkid/chorelist"

querystring = {"idChoreList":""}

headers = {"x-auth": "{{apiKey}}"}

response = requests.delete(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/kkid/chorelist"

queryString <- list(idChoreList = "")

response <- VERB("DELETE", url, query = queryString, add_headers('x-auth' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/kkid/chorelist?idChoreList=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/kkid/chorelist') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['idChoreList'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/kkid/chorelist";

    let querystring = [
        ("idChoreList", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth", "{{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}}/kkid/chorelist?idChoreList=' \
  --header 'x-auth: {{apiKey}}'
http DELETE '{{baseUrl}}/kkid/chorelist?idChoreList=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/kkid/chorelist?idChoreList='
import Foundation

let headers = ["x-auth": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/chorelist?idChoreList=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "message": "success",
  "success": true
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "No Data Found",
  "status": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API account does not have access to this Verb Method!",
  "success": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API key is invalid or has expired!",
  "success": 0
}
DELETE deletes user
{{baseUrl}}/kkid/userlist
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/userlist?userID=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/kkid/userlist" {:headers {:x-auth "{{apiKey}}"}
                                                            :query-params {:userID ""}})
require "http/client"

url = "{{baseUrl}}/kkid/userlist?userID="
headers = HTTP::Headers{
  "x-auth" => "{{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}}/kkid/userlist?userID="),
    Headers =
    {
        { "x-auth", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/kkid/userlist?userID=");
var request = new RestRequest("", Method.Delete);
request.AddHeader("x-auth", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/kkid/userlist?userID="

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("x-auth", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/kkid/userlist?userID= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/kkid/userlist?userID=")
  .setHeader("x-auth", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/userlist?userID="))
    .header("x-auth", "{{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}}/kkid/userlist?userID=")
  .delete(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/kkid/userlist?userID=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/kkid/userlist?userID=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/kkid/userlist',
  params: {userID: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/kkid/userlist?userID=';
const options = {method: 'DELETE', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/kkid/userlist?userID=',
  method: 'DELETE',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/userlist?userID=")
  .delete(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/userlist?userID=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/kkid/userlist',
  qs: {userID: ''},
  headers: {'x-auth': '{{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}}/kkid/userlist');

req.query({
  userID: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/kkid/userlist',
  params: {userID: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/kkid/userlist?userID=';
const options = {method: 'DELETE', headers: {'x-auth': '{{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": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/kkid/userlist?userID="]
                                                       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}}/kkid/userlist?userID=" in
let headers = Header.add (Header.init ()) "x-auth" "{{apiKey}}" in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/kkid/userlist?userID=",
  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: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/kkid/userlist?userID=', [
  'headers' => [
    'x-auth' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/kkid/userlist');
$request->setMethod(HTTP_METH_DELETE);

$request->setQueryData([
  'userID' => ''
]);

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/userlist');
$request->setRequestMethod('DELETE');
$request->setQuery(new http\QueryString([
  'userID' => ''
]));

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/userlist?userID=' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/userlist?userID=' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth': "{{apiKey}}" }

conn.request("DELETE", "/baseUrl/kkid/userlist?userID=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/kkid/userlist"

querystring = {"userID":""}

headers = {"x-auth": "{{apiKey}}"}

response = requests.delete(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/kkid/userlist"

queryString <- list(userID = "")

response <- VERB("DELETE", url, query = queryString, add_headers('x-auth' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/kkid/userlist?userID=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["x-auth"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/kkid/userlist') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['userID'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/kkid/userlist";

    let querystring = [
        ("userID", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth", "{{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}}/kkid/userlist?userID=' \
  --header 'x-auth: {{apiKey}}'
http DELETE '{{baseUrl}}/kkid/userlist?userID=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method DELETE \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/kkid/userlist?userID='
import Foundation

let headers = ["x-auth": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/userlist?userID=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API account does not have access to this Verb Method!",
  "success": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API key is invalid or has expired!",
  "success": 0
}
GET returns allowance balance and allowance transactions
{{baseUrl}}/kkid/allowance
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

kidUserId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/allowance?kidUserId=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/kkid/allowance" {:headers {:x-auth "{{apiKey}}"}
                                                          :query-params {:kidUserId ""}})
require "http/client"

url = "{{baseUrl}}/kkid/allowance?kidUserId="
headers = HTTP::Headers{
  "x-auth" => "{{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}}/kkid/allowance?kidUserId="),
    Headers =
    {
        { "x-auth", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/kkid/allowance?kidUserId=");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/kkid/allowance?kidUserId="

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/kkid/allowance?kidUserId= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/kkid/allowance?kidUserId=")
  .setHeader("x-auth", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/allowance?kidUserId="))
    .header("x-auth", "{{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}}/kkid/allowance?kidUserId=")
  .get()
  .addHeader("x-auth", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/kkid/allowance?kidUserId=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/kkid/allowance?kidUserId=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/kkid/allowance',
  params: {kidUserId: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/kkid/allowance?kidUserId=';
const options = {method: 'GET', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/kkid/allowance?kidUserId=',
  method: 'GET',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/allowance?kidUserId=")
  .get()
  .addHeader("x-auth", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/allowance?kidUserId=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/kkid/allowance',
  qs: {kidUserId: ''},
  headers: {'x-auth': '{{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}}/kkid/allowance');

req.query({
  kidUserId: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/kkid/allowance',
  params: {kidUserId: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/kkid/allowance?kidUserId=';
const options = {method: 'GET', headers: {'x-auth': '{{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": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/kkid/allowance?kidUserId="]
                                                       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}}/kkid/allowance?kidUserId=" in
let headers = Header.add (Header.init ()) "x-auth" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/kkid/allowance?kidUserId=",
  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: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/kkid/allowance?kidUserId=', [
  'headers' => [
    'x-auth' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/kkid/allowance');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'kidUserId' => ''
]);

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/allowance');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'kidUserId' => ''
]));

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/allowance?kidUserId=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/allowance?kidUserId=' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth': "{{apiKey}}" }

conn.request("GET", "/baseUrl/kkid/allowance?kidUserId=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/kkid/allowance"

querystring = {"kidUserId":""}

headers = {"x-auth": "{{apiKey}}"}

response = requests.get(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/kkid/allowance"

queryString <- list(kidUserId = "")

response <- VERB("GET", url, query = queryString, add_headers('x-auth' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/kkid/allowance?kidUserId=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/kkid/allowance') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['kidUserId'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/kkid/allowance";

    let querystring = [
        ("kidUserId", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth", "{{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}}/kkid/allowance?kidUserId=' \
  --header 'x-auth: {{apiKey}}'
http GET '{{baseUrl}}/kkid/allowance?kidUserId=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/kkid/allowance?kidUserId='
import Foundation

let headers = ["x-auth": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/allowance?kidUserId=")! 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

{
  "allowanceTransaction": [
    {
      "amount": 10,
      "date": {},
      "transactionDescription": "Weekly Allowance for Chores",
      "transactionId": 85,
      "transactionType": "Add",
      "userId": 1
    },
    {
      "amount": 10,
      "date": {},
      "transactionDescription": "Weekly Allowance for Chores",
      "transactionId": 85,
      "transactionType": "Add",
      "userId": 1
    }
  ],
  "balance": 0,
  "id": 24,
  "lastUpdated": "{}",
  "success": 1
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "No Data Found",
  "status": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API account does not have access to this Verb Method!",
  "success": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API key is invalid or has expired!",
  "success": 0
}
GET returns list of chores for given user
{{baseUrl}}/kkid/chorelist
HEADERS

X-Auth
{{apiKey}}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/chorelist");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/kkid/chorelist" {:headers {:x-auth "{{apiKey}}"}})
require "http/client"

url = "{{baseUrl}}/kkid/chorelist"
headers = HTTP::Headers{
  "x-auth" => "{{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}}/kkid/chorelist"),
    Headers =
    {
        { "x-auth", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/kkid/chorelist");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-auth", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/kkid/chorelist"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("x-auth", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/kkid/chorelist HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/kkid/chorelist")
  .setHeader("x-auth", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/chorelist"))
    .header("x-auth", "{{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}}/kkid/chorelist")
  .get()
  .addHeader("x-auth", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/kkid/chorelist")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/kkid/chorelist');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/kkid/chorelist',
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/kkid/chorelist';
const options = {method: 'GET', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/kkid/chorelist',
  method: 'GET',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/chorelist")
  .get()
  .addHeader("x-auth", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/chorelist',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/kkid/chorelist',
  headers: {'x-auth': '{{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}}/kkid/chorelist');

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/kkid/chorelist',
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/kkid/chorelist';
const options = {method: 'GET', headers: {'x-auth': '{{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": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/kkid/chorelist"]
                                                       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}}/kkid/chorelist" in
let headers = Header.add (Header.init ()) "x-auth" "{{apiKey}}" in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/kkid/chorelist",
  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: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/kkid/chorelist', [
  'headers' => [
    'x-auth' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/kkid/chorelist');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/chorelist');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/chorelist' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/chorelist' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth': "{{apiKey}}" }

conn.request("GET", "/baseUrl/kkid/chorelist", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/kkid/chorelist"

headers = {"x-auth": "{{apiKey}}"}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/kkid/chorelist"

response <- VERB("GET", url, add_headers('x-auth' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/kkid/chorelist")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["x-auth"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/kkid/chorelist') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/kkid/chorelist";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth", "{{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}}/kkid/chorelist \
  --header 'x-auth: {{apiKey}}'
http GET {{baseUrl}}/kkid/chorelist \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method GET \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - {{baseUrl}}/kkid/chorelist
import Foundation

let headers = ["x-auth": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/chorelist")! 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

{
  "chore": [
    {
      "aiIcon": "n",
      "altitude": 1,
      "blockDash": false,
      "choreDescription": "Wash dishes and clean off counter",
      "choreName": "Wash Dishes",
      "choreNumber": 1,
      "day": "Monday",
      "extraAllowance": 5,
      "idChoreList": 1,
      "isCalendar": false,
      "kid": "jane",
      "latitude": 0,
      "longitude": 6,
      "nfcTag": "kkids//Chores?washdishestag",
      "notes": "notes",
      "oneTime": false,
      "optional": false,
      "reassignable": true,
      "reassigned": false,
      "requireObjectDetection": "bed",
      "startDate": {},
      "status": "todo",
      "stolen": false,
      "stolenBy": "stolenBy",
      "updated": {},
      "updatedBy": "janedoe"
    },
    {
      "aiIcon": "n",
      "altitude": 1,
      "blockDash": false,
      "choreDescription": "Wash dishes and clean off counter",
      "choreName": "Wash Dishes",
      "choreNumber": 1,
      "day": "Monday",
      "extraAllowance": 5,
      "idChoreList": 1,
      "isCalendar": false,
      "kid": "jane",
      "latitude": 0,
      "longitude": 6,
      "nfcTag": "kkids//Chores?washdishestag",
      "notes": "notes",
      "oneTime": false,
      "optional": false,
      "reassignable": true,
      "reassigned": false,
      "requireObjectDetection": "bed",
      "startDate": {},
      "status": "todo",
      "stolen": false,
      "stolenBy": "stolenBy",
      "updated": {},
      "updatedBy": "janedoe"
    }
  ],
  "success": 1
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "No Data Found",
  "status": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API account does not have access to this Verb Method!",
  "success": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API key is invalid or has expired!",
  "success": 0
}
GET returns list of users
{{baseUrl}}/kkid/userlist
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/userlist");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/kkid/userlist")
require "http/client"

url = "{{baseUrl}}/kkid/userlist"

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}}/kkid/userlist"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/kkid/userlist");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/kkid/userlist"

	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/kkid/userlist HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/kkid/userlist")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/userlist"))
    .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}}/kkid/userlist")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/kkid/userlist")
  .asString();
const 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}}/kkid/userlist');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/kkid/userlist'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/kkid/userlist';
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}}/kkid/userlist',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/userlist")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/userlist',
  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}}/kkid/userlist'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/kkid/userlist');

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}}/kkid/userlist'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/kkid/userlist';
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}}/kkid/userlist"]
                                                       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}}/kkid/userlist" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/kkid/userlist",
  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}}/kkid/userlist');

echo $response->getBody();
setUrl('{{baseUrl}}/kkid/userlist');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/userlist');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/userlist' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/userlist' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/kkid/userlist")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/kkid/userlist"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/kkid/userlist"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/kkid/userlist")

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/kkid/userlist') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/kkid/userlist";

    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}}/kkid/userlist
http GET {{baseUrl}}/kkid/userlist
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/kkid/userlist
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/userlist")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "success": true,
  "user": [
    {
      "email": "jane@doe.com",
      "emoji": "🤗",
      "enableAllowance": true,
      "enableBehaviorChart": false,
      "enableChores": true,
      "enableNoAds": false,
      "enableObjectDetection": false,
      "enableTmdb": true,
      "firstName": "Jane",
      "homeId": 1,
      "isActive": true,
      "isAdmin": false,
      "isBanned": false,
      "isChild": true,
      "isDisabled": false,
      "isLocked": false,
      "isMaster": false,
      "lastName": "Doe",
      "masterId": 1,
      "pushAllowance": true,
      "pushAllowanceNew": true,
      "pushChores": true,
      "pushChoresNew": true,
      "pushChoresReminders": true,
      "tmdbKey": "9a87huiufe94r8",
      "userId": 10,
      "username": "janedoe",
      "weeklyAllowance": 5
    },
    {
      "email": "jane@doe.com",
      "emoji": "🤗",
      "enableAllowance": true,
      "enableBehaviorChart": false,
      "enableChores": true,
      "enableNoAds": false,
      "enableObjectDetection": false,
      "enableTmdb": true,
      "firstName": "Jane",
      "homeId": 1,
      "isActive": true,
      "isAdmin": false,
      "isBanned": false,
      "isChild": true,
      "isDisabled": false,
      "isLocked": false,
      "isMaster": false,
      "lastName": "Doe",
      "masterId": 1,
      "pushAllowance": true,
      "pushAllowanceNew": true,
      "pushChores": true,
      "pushChoresNew": true,
      "pushChoresReminders": true,
      "tmdbKey": "9a87huiufe94r8",
      "userId": 10,
      "username": "janedoe",
      "weeklyAllowance": 5
    }
  ]
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "No Data Found",
  "status": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API account does not have access to this Verb Method!",
  "success": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API key is invalid or has expired!",
  "success": 0
}
POST subscribes-unsubscribes-registers for apns push notifications
{{baseUrl}}/kkid/apns
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

kidUserId
tool
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/apns?kidUserId=&tool=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/kkid/apns" {:headers {:x-auth "{{apiKey}}"}
                                                      :query-params {:kidUserId ""
                                                                     :tool ""}})
require "http/client"

url = "{{baseUrl}}/kkid/apns?kidUserId=&tool="
headers = HTTP::Headers{
  "x-auth" => "{{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}}/kkid/apns?kidUserId=&tool="),
    Headers =
    {
        { "x-auth", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/kkid/apns?kidUserId=&tool=");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-auth", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/kkid/apns?kidUserId=&tool="

	req, _ := http.NewRequest("POST", url, nil)

	req.Header.Add("x-auth", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/kkid/apns?kidUserId=&tool= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/kkid/apns?kidUserId=&tool=")
  .setHeader("x-auth", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/apns?kidUserId=&tool="))
    .header("x-auth", "{{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}}/kkid/apns?kidUserId=&tool=")
  .post(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/kkid/apns?kidUserId=&tool=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/kkid/apns?kidUserId=&tool=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/kkid/apns',
  params: {kidUserId: '', tool: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/kkid/apns?kidUserId=&tool=';
const options = {method: 'POST', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/kkid/apns?kidUserId=&tool=',
  method: 'POST',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/apns?kidUserId=&tool=")
  .post(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/apns?kidUserId=&tool=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/kkid/apns',
  qs: {kidUserId: '', tool: ''},
  headers: {'x-auth': '{{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}}/kkid/apns');

req.query({
  kidUserId: '',
  tool: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/kkid/apns',
  params: {kidUserId: '', tool: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/kkid/apns?kidUserId=&tool=';
const options = {method: 'POST', headers: {'x-auth': '{{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": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/kkid/apns?kidUserId=&tool="]
                                                       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}}/kkid/apns?kidUserId=&tool=" in
let headers = Header.add (Header.init ()) "x-auth" "{{apiKey}}" in

Client.call ~headers `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/kkid/apns?kidUserId=&tool=",
  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: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/kkid/apns?kidUserId=&tool=', [
  'headers' => [
    'x-auth' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/kkid/apns');
$request->setMethod(HTTP_METH_POST);

$request->setQueryData([
  'kidUserId' => '',
  'tool' => ''
]);

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/apns');
$request->setRequestMethod('POST');
$request->setQuery(new http\QueryString([
  'kidUserId' => '',
  'tool' => ''
]));

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/apns?kidUserId=&tool=' -Method POST -Headers $headers
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/apns?kidUserId=&tool=' -Method POST -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth': "{{apiKey}}" }

conn.request("POST", "/baseUrl/kkid/apns?kidUserId=&tool=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/kkid/apns"

querystring = {"kidUserId":"","tool":""}

headers = {"x-auth": "{{apiKey}}"}

response = requests.post(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/kkid/apns"

queryString <- list(
  kidUserId = "",
  tool = ""
)

response <- VERB("POST", url, query = queryString, add_headers('x-auth' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/kkid/apns?kidUserId=&tool=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["x-auth"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/kkid/apns') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['kidUserId'] = ''
  req.params['tool'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/kkid/apns";

    let querystring = [
        ("kidUserId", ""),
        ("tool", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .query(&querystring)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url '{{baseUrl}}/kkid/apns?kidUserId=&tool=' \
  --header 'x-auth: {{apiKey}}'
http POST '{{baseUrl}}/kkid/apns?kidUserId=&tool=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/kkid/apns?kidUserId=&tool='
import Foundation

let headers = ["x-auth": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/apns?kidUserId=&tool=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "message": "success",
  "success": true
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "No Data Found",
  "status": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API account does not have access to this Verb Method!",
  "success": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API key is invalid or has expired!",
  "success": 0
}
PUT updates chore for given chore id
{{baseUrl}}/kkid/chorelist
HEADERS

X-Auth
{{apiKey}}
QUERY PARAMS

idChoreList
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/chorelist?idChoreList=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-auth: {{apiKey}}");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/kkid/chorelist" {:headers {:x-auth "{{apiKey}}"}
                                                          :query-params {:idChoreList ""}})
require "http/client"

url = "{{baseUrl}}/kkid/chorelist?idChoreList="
headers = HTTP::Headers{
  "x-auth" => "{{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}}/kkid/chorelist?idChoreList="),
    Headers =
    {
        { "x-auth", "{{apiKey}}" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/kkid/chorelist?idChoreList=");
var request = new RestRequest("", Method.Put);
request.AddHeader("x-auth", "{{apiKey}}");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/kkid/chorelist?idChoreList="

	req, _ := http.NewRequest("PUT", url, nil)

	req.Header.Add("x-auth", "{{apiKey}}")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/kkid/chorelist?idChoreList= HTTP/1.1
X-Auth: {{apiKey}}
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/kkid/chorelist?idChoreList=")
  .setHeader("x-auth", "{{apiKey}}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/chorelist?idChoreList="))
    .header("x-auth", "{{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}}/kkid/chorelist?idChoreList=")
  .put(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/kkid/chorelist?idChoreList=")
  .header("x-auth", "{{apiKey}}")
  .asString();
const 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}}/kkid/chorelist?idChoreList=');
xhr.setRequestHeader('x-auth', '{{apiKey}}');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/kkid/chorelist',
  params: {idChoreList: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/kkid/chorelist?idChoreList=';
const options = {method: 'PUT', headers: {'x-auth': '{{apiKey}}'}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/kkid/chorelist?idChoreList=',
  method: 'PUT',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/chorelist?idChoreList=")
  .put(null)
  .addHeader("x-auth", "{{apiKey}}")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/chorelist?idChoreList=',
  headers: {
    'x-auth': '{{apiKey}}'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/kkid/chorelist',
  qs: {idChoreList: ''},
  headers: {'x-auth': '{{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}}/kkid/chorelist');

req.query({
  idChoreList: ''
});

req.headers({
  'x-auth': '{{apiKey}}'
});

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}}/kkid/chorelist',
  params: {idChoreList: ''},
  headers: {'x-auth': '{{apiKey}}'}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/kkid/chorelist?idChoreList=';
const options = {method: 'PUT', headers: {'x-auth': '{{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": @"{{apiKey}}" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/kkid/chorelist?idChoreList="]
                                                       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}}/kkid/chorelist?idChoreList=" in
let headers = Header.add (Header.init ()) "x-auth" "{{apiKey}}" in

Client.call ~headers `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/kkid/chorelist?idChoreList=",
  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: {{apiKey}}"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/kkid/chorelist?idChoreList=', [
  'headers' => [
    'x-auth' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/kkid/chorelist');
$request->setMethod(HTTP_METH_PUT);

$request->setQueryData([
  'idChoreList' => ''
]);

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/chorelist');
$request->setRequestMethod('PUT');
$request->setQuery(new http\QueryString([
  'idChoreList' => ''
]));

$request->setHeaders([
  'x-auth' => '{{apiKey}}'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/chorelist?idChoreList=' -Method PUT -Headers $headers
$headers=@{}
$headers.Add("x-auth", "{{apiKey}}")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/chorelist?idChoreList=' -Method PUT -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = { 'x-auth': "{{apiKey}}" }

conn.request("PUT", "/baseUrl/kkid/chorelist?idChoreList=", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/kkid/chorelist"

querystring = {"idChoreList":""}

headers = {"x-auth": "{{apiKey}}"}

response = requests.put(url, headers=headers, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/kkid/chorelist"

queryString <- list(idChoreList = "")

response <- VERB("PUT", url, query = queryString, add_headers('x-auth' = '{{apiKey}}'), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/kkid/chorelist?idChoreList=")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["x-auth"] = '{{apiKey}}'

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.put('/baseUrl/kkid/chorelist') do |req|
  req.headers['x-auth'] = '{{apiKey}}'
  req.params['idChoreList'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/kkid/chorelist";

    let querystring = [
        ("idChoreList", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-auth", "{{apiKey}}".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .query(&querystring)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url '{{baseUrl}}/kkid/chorelist?idChoreList=' \
  --header 'x-auth: {{apiKey}}'
http PUT '{{baseUrl}}/kkid/chorelist?idChoreList=' \
  x-auth:'{{apiKey}}'
wget --quiet \
  --method PUT \
  --header 'x-auth: {{apiKey}}' \
  --output-document \
  - '{{baseUrl}}/kkid/chorelist?idChoreList='
import Foundation

let headers = ["x-auth": "{{apiKey}}"]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/chorelist?idChoreList=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "message": "success",
  "success": true
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "No Data Found",
  "status": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API account does not have access to this Verb Method!",
  "success": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API key is invalid or has expired!",
  "success": 0
}
PUT updates user
{{baseUrl}}/kkid/userlist
QUERY PARAMS

userID
username
email
firstName
lastName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/kkid/userlist" {:query-params {:userID ""
                                                                        :username ""
                                                                        :email ""
                                                                        :firstName ""
                                                                        :lastName ""}})
require "http/client"

url = "{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName="

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}}/kkid/userlist?userID=&username=&email=&firstName=&lastName="),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=");
var request = new RestRequest("", Method.Put);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName="

	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/kkid/userlist?userID=&username=&email=&firstName=&lastName= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName="))
    .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}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=")
  .put(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=")
  .asString();
const 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}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/kkid/userlist',
  params: {userID: '', username: '', email: '', firstName: '', lastName: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=';
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}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=',
  method: 'PUT',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=")
  .put(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/kkid/userlist?userID=&username=&email=&firstName=&lastName=',
  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}}/kkid/userlist',
  qs: {userID: '', username: '', email: '', firstName: '', lastName: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/kkid/userlist');

req.query({
  userID: '',
  username: '',
  email: '',
  firstName: '',
  lastName: ''
});

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}}/kkid/userlist',
  params: {userID: '', username: '', email: '', firstName: '', lastName: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=';
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}}/kkid/userlist?userID=&username=&email=&firstName=&lastName="]
                                                       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}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=" in

Client.call `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=",
  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}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=');

echo $response->getBody();
setUrl('{{baseUrl}}/kkid/userlist');
$request->setMethod(HTTP_METH_PUT);

$request->setQueryData([
  'userID' => '',
  'username' => '',
  'email' => '',
  'firstName' => '',
  'lastName' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/kkid/userlist');
$request->setRequestMethod('PUT');
$request->setQuery(new http\QueryString([
  'userID' => '',
  'username' => '',
  'email' => '',
  'firstName' => '',
  'lastName' => ''
]));

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=' -Method PUT 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=' -Method PUT 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("PUT", "/baseUrl/kkid/userlist?userID=&username=&email=&firstName=&lastName=")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/kkid/userlist"

querystring = {"userID":"","username":"","email":"","firstName":"","lastName":""}

response = requests.put(url, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/kkid/userlist"

queryString <- list(
  userID = "",
  username = "",
  email = "",
  firstName = "",
  lastName = ""
)

response <- VERB("PUT", url, query = queryString, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=")

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/kkid/userlist') do |req|
  req.params['userID'] = ''
  req.params['username'] = ''
  req.params['email'] = ''
  req.params['firstName'] = ''
  req.params['lastName'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/kkid/userlist";

    let querystring = [
        ("userID", ""),
        ("username", ""),
        ("email", ""),
        ("firstName", ""),
        ("lastName", ""),
    ];

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .query(&querystring)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url '{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName='
http PUT '{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName='
wget --quiet \
  --method PUT \
  --output-document \
  - '{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName='
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/kkid/userlist?userID=&username=&email=&firstName=&lastName=")! 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()
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "added": {},
  "aff_added": "aff_added",
  "aff_id": "aff_id",
  "aff_payout_type": "aff_payout_type",
  "avatar": "avatar",
  "city": "city",
  "comment": "Added Via KKids API",
  "country": "country",
  "disable_lock_until": "disable_lock_until",
  "email": "jane@doe.com",
  "i_agree": "0",
  "is_affiliate": "is_affiliate",
  "is_locked": "0",
  "lang": "lang",
  "last_login": "last_login",
  "login": "janedoe",
  "name_f": "Jane",
  "name_l": "Doe",
  "pass": "pass",
  "pass_dattm": {},
  "phone": "phone",
  "pin": "0",
  "plain_password": "plain_password",
  "remember_key": "remember_key",
  "remote_addr": "104.237.5.109",
  "require_consent": "require_consent",
  "reseller_id": "reseller_id",
  "saved_form_id": "saved_form_id",
  "state": "state",
  "status": "0",
  "street": "street",
  "street2": "street2",
  "subusers_parent_id": "0",
  "tax_id": "tax_id",
  "unsubscribed": "0",
  "user_agent": "user_agent",
  "user_id": 1,
  "zip": "zip"
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API account does not have access to this Verb Method!",
  "success": 0
}
RESPONSE HEADERS

Content-Type
application/json
RESPONSE BODY json

{
  "error": "API Access Denied! Your API key is invalid or has expired!",
  "success": 0
}